Merge pull request #19663 from lorentey/default-subscript-is-slow

[stdlib] Force-inline Dictionary.subscript(_:, default:)._modify
diff --git a/benchmark/scripts/compare_perf_tests.py b/benchmark/scripts/compare_perf_tests.py
index bbf8ce5..fe3a84b 100755
--- a/benchmark/scripts/compare_perf_tests.py
+++ b/benchmark/scripts/compare_perf_tests.py
@@ -34,8 +34,7 @@
 import sys
 from bisect import bisect, bisect_left, bisect_right
 from collections import namedtuple
-from decimal import Decimal, ROUND_HALF_EVEN
-from math import sqrt
+from math import ceil, sqrt
 
 
 class Sample(namedtuple('Sample', 'i num_iters runtime')):
@@ -143,15 +142,12 @@
         return self.samples[-1].runtime
 
     def quantile(self, q):
-        """Return runtime of a sample nearest to the quantile.
+        """Return runtime for given quantile.
 
-        Explicitly uses round-half-to-even rounding algorithm to match the
-        behavior of numpy's quantile(interpolation='nearest') and quantile
-        estimate type R-3, SAS-2. See:
+        Equivalent to quantile estimate type R-1, SAS-3. See:
         https://en.wikipedia.org/wiki/Quantile#Estimating_quantiles_from_a_sample
         """
-        index = int(Decimal((self.count - 1) * Decimal(q))
-                    .quantize(0, ROUND_HALF_EVEN))
+        index = max(0, int(ceil(self.count * float(q))) - 1)
         return self.samples[index].runtime
 
     @property
diff --git a/benchmark/scripts/test_compare_perf_tests.py b/benchmark/scripts/test_compare_perf_tests.py
index 89e62c9..bf530e7 100644
--- a/benchmark/scripts/test_compare_perf_tests.py
+++ b/benchmark/scripts/test_compare_perf_tests.py
@@ -62,6 +62,17 @@
         self.assertEquals(s.num_iters, 42)
         self.assertEquals(s.runtime, 1000)
 
+    def test_quantile(self):
+        self.assertEquals(self.samples.quantile(1), 1000)
+        self.assertEquals(self.samples.quantile(0), 1000)
+        self.samples.add(Sample(2, 1, 1100))
+        self.assertEquals(self.samples.quantile(0), 1000)
+        self.assertEquals(self.samples.quantile(1), 1100)
+        self.samples.add(Sample(3, 1, 1050))
+        self.assertEquals(self.samples.quantile(0), 1000)
+        self.assertEquals(self.samples.quantile(.5), 1050)
+        self.assertEquals(self.samples.quantile(1), 1100)
+
     def assertEqualFiveNumberSummary(self, ss, expected_fns):
         e_min, e_q1, e_median, e_q3, e_max = expected_fns
         self.assertEquals(ss.min, e_min)
@@ -81,7 +92,7 @@
             self.samples, (1000, 1000, 1050, 1100, 1100))
         self.samples.add(Sample(4, 1, 1025))
         self.assertEqualFiveNumberSummary(
-            self.samples, (1000, 1025, 1050, 1050, 1100))
+            self.samples, (1000, 1000, 1025, 1050, 1100))
         self.samples.add(Sample(5, 1, 1075))
         self.assertEqualFiveNumberSummary(
             self.samples, (1000, 1025, 1050, 1075, 1100))
@@ -447,7 +458,7 @@
         self.assertTrue(isinstance(result, PerformanceTestResult))
         self.assertEquals(result.min, 350815)
         self.assertEquals(result.max, 376131)
-        self.assertEquals(result.median, 363094)
+        self.assertEquals(result.median, 358817)
         self.assertAlmostEquals(result.sd, 8443.37, places=2)
         self.assertAlmostEquals(result.mean, 361463.25, places=2)
         self.assertEquals(result.num_samples, 8)
diff --git a/benchmark/utils/DriverUtils.swift b/benchmark/utils/DriverUtils.swift
index 09ab737..1d31d37 100644
--- a/benchmark/utils/DriverUtils.swift
+++ b/benchmark/utils/DriverUtils.swift
@@ -31,15 +31,13 @@
     self.stats = self.samples.reduce(into: Stats(), Stats.collect)
   }
 
-  /// Return sample at index nearest to the `quantile`.
+  /// Return measured value for given `quantile`.
   ///
-  /// Explicitly uses round-half-to-even rounding algorithm to match the
-  /// behavior of numpy's quantile(interpolation='nearest') and quantile
-  /// estimate type R-3, SAS-2. See:
+  /// Equivalent to quantile estimate type R-1, SAS-3. See:
   /// https://en.wikipedia.org/wiki/Quantile#Estimating_quantiles_from_a_sample
   subscript(_ quantile: Double) -> T {
-    let index = Int(
-      (Double(samples.count - 1) * quantile).rounded(.toNearestOrEven))
+    let index = Swift.max(0,
+      Int((Double(samples.count) * quantile).rounded(.up)) - 1)
     return samples[index]
   }
 
diff --git a/include/swift/AST/DiagnosticsModuleDiffer.def b/include/swift/AST/DiagnosticsModuleDiffer.def
index 49e39a1..5218616 100644
--- a/include/swift/AST/DiagnosticsModuleDiffer.def
+++ b/include/swift/AST/DiagnosticsModuleDiffer.def
@@ -58,6 +58,8 @@
 
 ERROR(decl_added,none,"%0 is added to a non-resilient type", (StringRef))
 
+ERROR(decl_has_fixed_order_change,none,"%0 is %select{now|no longer}1 a property with fixed layout order", (StringRef, bool))
+
 ERROR(default_arg_removed,none,"%0 has removed default argument from %1", (StringRef, StringRef))
 
 ERROR(conformance_removed,none,"%0 has removed %select{conformance to|inherited protocol}2 %1", (StringRef, StringRef, bool))
diff --git a/include/swift/IDE/DigesterEnums.def b/include/swift/IDE/DigesterEnums.def
index a54aba3..c1e676c 100644
--- a/include/swift/IDE/DigesterEnums.def
+++ b/include/swift/IDE/DigesterEnums.def
@@ -67,6 +67,7 @@
 NODE_KIND(DeclSubscript, Subscript)
 NODE_KIND_RANGE(DeclAbstractFunc, DeclFunction, DeclSubscript)
 
+NODE_KIND(DeclOperator, OperatorDecl)
 NODE_KIND(DeclType, TypeDecl)
 NODE_KIND(DeclVar, Var)
 NODE_KIND(DeclTypeAlias, TypeAlias)
diff --git a/include/swift/SIL/ApplySite.h b/include/swift/SIL/ApplySite.h
index 27d5e74..0d3a663 100644
--- a/include/swift/SIL/ApplySite.h
+++ b/include/swift/SIL/ApplySite.h
@@ -1,4 +1,4 @@
-//===--- ApplySite.h ------------------------------------------------------===//
+//===--- ApplySite.h -------------------------------------*- mode: c++ -*--===//
 //
 // This source file is part of the Swift.org open source project
 //
@@ -459,6 +459,18 @@
     return getArguments().slice(getNumIndirectSILResults());
   }
 
+  /// Returns true if \p op is the callee operand of this apply site
+  /// and not an argument operand.
+  bool isCalleeOperand(const Operand &op) const {
+    return op.getOperandNumber() < getOperandIndexOfFirstArgument();
+  }
+
+  /// Returns true if \p op is an operand that passes an indirect
+  /// result argument to the apply site.
+  bool isIndirectResultOperand(const Operand &op) const {
+    return getCalleeArgIndex(op) < getNumIndirectSILResults();
+  }
+
   static FullApplySite getFromOpaqueValue(void *p) { return FullApplySite(p); }
 
   static bool classof(const SILInstruction *inst) {
diff --git a/include/swift/SIL/OwnershipUtils.h b/include/swift/SIL/OwnershipUtils.h
index 8fe9aed..10aac33 100644
--- a/include/swift/SIL/OwnershipUtils.h
+++ b/include/swift/SIL/OwnershipUtils.h
@@ -64,26 +64,26 @@
 /// so types/etc do not leak.
 struct OwnershipChecker {
   /// The list of regular users from the last run of the checker.
-  SmallVector<SILInstruction *, 16> RegularUsers;
+  SmallVector<SILInstruction *, 16> regularUsers;
 
   /// The list of regular users from the last run of the checker.
-  SmallVector<SILInstruction *, 16> LifetimeEndingUsers;
+  SmallVector<SILInstruction *, 16> lifetimeEndingUsers;
 
   /// The live blocks for the SILValue we processed. This can be used to
   /// determine if a block is in the "live" region of our SILInstruction.
-  SmallPtrSet<SILBasicBlock *, 32> LiveBlocks;
+  SmallPtrSet<SILBasicBlock *, 32> liveBlocks;
 
   /// The list of implicit regular users from the last run of the checker.
   ///
   /// This is used to encode end of scope like instructions.
-  SmallVector<SILInstruction *, 4> ImplicitRegularUsers;
+  SmallVector<SILInstruction *, 4> endScopeRegularUsers;
 
   /// The module that we are in.
-  SILModule &Mod;
+  SILModule &mod;
 
   /// A cache of dead-end basic blocks that we use to determine if we can
   /// ignore "leaks".
-  DeadEndBlocks &DEBlocks;
+  DeadEndBlocks &deadEndBlocks;
 
   bool checkValue(SILValue Value);
 };
@@ -98,7 +98,7 @@
                             ArrayRef<BranchPropagatedUser> consumingUses,
                             ArrayRef<BranchPropagatedUser> nonConsumingUses,
                             SmallPtrSetImpl<SILBasicBlock *> &visitedBlocks,
-                            DeadEndBlocks &deBlocks,
+                            DeadEndBlocks &deadEndBlocks,
                             ownership::ErrorBehaviorKind errorBehavior);
 
 } // namespace swift
diff --git a/include/swift/SIL/SILModule.h b/include/swift/SIL/SILModule.h
index 01cea12..46b2349 100644
--- a/include/swift/SIL/SILModule.h
+++ b/include/swift/SIL/SILModule.h
@@ -378,6 +378,8 @@
     return wholeModule;
   }
 
+  bool isStdlibModule() const;
+
   /// Returns true if it is the optimized OnoneSupport module.
   bool isOptimizedOnoneSupportModule() const;
 
diff --git a/include/swift/SIL/SILValue.h b/include/swift/SIL/SILValue.h
index 322c561..4172f54 100644
--- a/include/swift/SIL/SILValue.h
+++ b/include/swift/SIL/SILValue.h
@@ -55,6 +55,33 @@
   return llvm::hash_value(size_t(K));
 }
 
+/// What constraint does the given use of an SSA value put on the lifetime of
+/// the given SSA value.
+///
+/// There are two possible constraints: MustBeLive and
+/// MustBeInvalidated. MustBeLive means that the SSA value must be able to be
+/// used in a valid way at the given use point. MustBeInvalidated means that any
+/// use of given SSA value after this instruction on any path through this
+/// instruction.
+enum class UseLifetimeConstraint {
+  /// This use requires the SSA value to be live after the given instruction's
+  /// execution.
+  MustBeLive,
+
+  /// This use invalidates the given SSA value.
+  ///
+  /// This means that the given SSA value can not have any uses that are
+  /// reachable from this instruction. When a value has owned semantics this
+  /// means the SSA value is destroyed at this point. When a value has
+  /// guaranteed (i.e. shared borrow) semantics this means that the program
+  /// has left the scope of the borrowed SSA value and said value can not be
+  /// used.
+  MustBeInvalidated,
+};
+
+llvm::raw_ostream &operator<<(llvm::raw_ostream &os,
+                              UseLifetimeConstraint constraint);
+
 /// A value representing the specific ownership semantics that a SILValue may
 /// have.
 struct ValueOwnershipKind {
@@ -64,27 +91,23 @@
     /// with Trivial ownership kind can be used. Other side effects (e.g. Memory
     /// dependencies) must still be respected. A SILValue with Trivial ownership
     /// kind must be of Trivial SILType (i.e. SILType::isTrivial(SILModule &)
-    /// must
-    /// return true).
+    /// must return true).
     ///
     /// Some examples of SIL types with Trivial ownership are: Builtin.Int32,
     /// Builtin.RawPointer, aggregates containing all trivial types.
     Trivial,
 
     /// A SILValue with `Unowned` ownership kind is an independent value that
-    /// has
-    /// a lifetime that is only guaranteed to last until the next program
-    /// visible
-    /// side-effect. To maintain the lifetime of an unowned value, it must be
-    /// converted to an owned representation via a copy_value.
+    /// has a lifetime that is only guaranteed to last until the next program
+    /// visible side-effect. To maintain the lifetime of an unowned value, it
+    /// must be converted to an owned representation via a copy_value.
     ///
     /// Unowned ownership kind occurs mainly along method/function boundaries in
     /// between Swift and Objective-C code.
     Unowned,
 
     /// A SILValue with `Owned` ownership kind is an independent value that has
-    /// an
-    /// ownership independent of any other ownership imbued within it. The
+    /// an ownership independent of any other ownership imbued within it. The
     /// SILValue must be paired with a consuming operation that ends the SSA
     /// value's lifetime exactly once along all paths through the program.
     Owned,
@@ -105,10 +128,9 @@
     Guaranteed,
 
     /// A SILValue with undefined ownership. It can pair with /Any/ ownership
-    /// kinds . This means that it could take on /any/ ownership semantics. This
+    /// kinds. This means that it could take on /any/ ownership semantics. This
     /// is meant only to model SILUndef and to express certain situations where
-    /// we
-    /// use unqualified ownership. Expected to tighten over time.
+    /// we use unqualified ownership. Expected to tighten over time.
     Any,
 
     LastValueOwnershipKind = Any,
@@ -151,6 +173,23 @@
   ValueOwnershipKind getProjectedOwnershipKind(SILModule &M,
                                                SILType Proj) const;
 
+  /// Return the lifetime constraint semantics for this
+  /// ValueOwnershipKind when forwarding ownership.
+  ///
+  /// This is MustBeInvalidated for Owned and MustBeLive for all other ownership
+  /// kinds.
+  UseLifetimeConstraint getForwardingLifetimeConstraint() const {
+    switch (Value) {
+    case ValueOwnershipKind::Trivial:
+    case ValueOwnershipKind::Any:
+    case ValueOwnershipKind::Guaranteed:
+    case ValueOwnershipKind::Unowned:
+      return UseLifetimeConstraint::MustBeLive;
+    case ValueOwnershipKind::Owned:
+      return UseLifetimeConstraint::MustBeInvalidated;
+    }
+  }
+
   /// Returns true if \p Other can be merged successfully with this, implying
   /// that the two ownership kinds are "compatibile".
   ///
@@ -347,6 +386,149 @@
                        DeadEndBlocks *DEBlocks = nullptr) const;
 };
 
+/// A map from a ValueOwnershipKind that an operand can accept to a
+/// UseLifetimeConstraint that describes the effect that the operand's use has
+/// on the underlying value. If a ValueOwnershipKind is not in this map then
+/// matching an operand with the value results in an ill formed program.
+///
+/// So for instance, a map could specify that if a value is used as an owned
+/// parameter, then the use implies that the original value is destroyed at that
+/// point. In contrast, if the value is used as a guaranteed parameter, then the
+/// liveness constraint just requires that the value remains alive at the use
+/// point.
+struct OperandOwnershipKindMap {
+  // One bit for if a value exists and if the value exists, what the
+  // ownership constraint is. These are stored as pairs.
+  //
+  // NOTE: We are burning 1 bit per unset value. But this is without
+  // matter since we are always going to need less bits than 64, so we
+  // should always have a small case SmallBitVector, so there is no
+  // difference in size.
+  static constexpr unsigned NUM_DATA_BITS =
+      2 * (unsigned(ValueOwnershipKind::LastValueOwnershipKind) + 1);
+
+  /// A bit vector representing our "map". Given a ValueOwnershipKind k, if the
+  /// operand can accept k, the unsigned(k)*2 bit will be set to true. Assuming
+  /// that bit is set, the unsigned(k)*2+1 bit is set to the use lifetime
+  /// constraint provided by the value.
+  SmallBitVector data;
+
+  OperandOwnershipKindMap() : data(NUM_DATA_BITS) {}
+  OperandOwnershipKindMap(ValueOwnershipKind kind,
+                          UseLifetimeConstraint constraint)
+      : data(NUM_DATA_BITS) {
+    add(kind, constraint);
+  }
+
+  /// Return the OperandOwnershipKindMap that tests for compatibility with
+  /// ValueOwnershipKind kind. This means that it will accept a element whose
+  /// ownership is ValueOwnershipKind::Any.
+  static OperandOwnershipKindMap
+  compatibilityMap(ValueOwnershipKind kind, UseLifetimeConstraint constraint) {
+    OperandOwnershipKindMap set;
+    set.addCompatibilityConstraint(kind, constraint);
+    return set;
+  }
+
+  /// Return a map that is compatible with any and all ValueOwnershipKinds
+  /// except for \p kind.
+  static OperandOwnershipKindMap
+  compatibleWithAllExcept(ValueOwnershipKind kind) {
+    OperandOwnershipKindMap map;
+    unsigned index = 0;
+    unsigned end = unsigned(ValueOwnershipKind::LastValueOwnershipKind) + 1;
+    for (; index != end; ++index) {
+      if (ValueOwnershipKind(index) == kind) {
+        continue;
+      }
+      map.add(ValueOwnershipKind(index), UseLifetimeConstraint::MustBeLive);
+    }
+    return map;
+  }
+
+  /// Create a map that has compatibility constraints for each of the
+  /// ValueOwnershipKind, UseLifetimeConstraints in \p args.
+  static OperandOwnershipKindMap
+  compatibilityMap(std::initializer_list<
+                   std::pair<ValueOwnershipKind, UseLifetimeConstraint>>
+                       args) {
+    OperandOwnershipKindMap map;
+    for (auto &p : args) {
+      map.addCompatibilityConstraint(p.first, p.second);
+    }
+    return map;
+  }
+
+  /// Return a map that states that an operand can take any ownership with each
+  /// ownership having a must be live constraint.
+  static OperandOwnershipKindMap allLive() {
+    OperandOwnershipKindMap map;
+    unsigned index = 0;
+    unsigned end = unsigned(ValueOwnershipKind::LastValueOwnershipKind) + 1;
+    while (index != end) {
+      map.add(ValueOwnershipKind(index), UseLifetimeConstraint::MustBeLive);
+      ++index;
+    }
+    return map;
+  }
+
+  /// Specify that the operand associated with this set can accept a value with
+  /// ValueOwnershipKind \p kind. The value provided by the operand will have a
+  /// new ownership enforced constraint defined by \p constraint.
+  void add(ValueOwnershipKind kind, UseLifetimeConstraint constraint) {
+    unsigned index = unsigned(kind);
+    unsigned kindOffset = index * 2;
+    unsigned constraintOffset = index * 2 + 1;
+
+    // If we have already put this kind into the map, we require the constraint
+    // offset to be the same, i.e. we only allow for a kind to be added twice if
+    // the constraint is idempotent. We assert otherwise.
+    assert((!data[kindOffset] || UseLifetimeConstraint(bool(
+                                     data[constraintOffset])) == constraint) &&
+           "Adding kind twice to the map with different constraints?!");
+    data[kindOffset] = true;
+    data[constraintOffset] = bool(constraint);
+  }
+
+  void addCompatibilityConstraint(ValueOwnershipKind kind,
+                                  UseLifetimeConstraint constraint) {
+    add(ValueOwnershipKind::Any, UseLifetimeConstraint::MustBeLive);
+    add(kind, constraint);
+  }
+
+  bool canAcceptKind(ValueOwnershipKind kind) const {
+    unsigned index = unsigned(kind);
+    unsigned kindOffset = index * 2;
+    return data[kindOffset];
+  }
+
+  UseLifetimeConstraint getLifetimeConstraint(ValueOwnershipKind kind) const;
+
+  void print(llvm::raw_ostream &os) const;
+  LLVM_ATTRIBUTE_DEPRECATED(void dump() const, "only for use in a debugger");
+};
+
+inline llvm::raw_ostream &operator<<(llvm::raw_ostream &os,
+                                     OperandOwnershipKindMap map) {
+  map.print(os);
+  return os;
+}
+
+// Out of line to work around lack of forward declaration for operator <<.
+inline UseLifetimeConstraint
+OperandOwnershipKindMap::getLifetimeConstraint(ValueOwnershipKind kind) const {
+#ifndef NDEBUG
+  if (!canAcceptKind(kind)) {
+    llvm::errs() << "Can not lookup lifetime constraint: " << kind
+                 << ". Not in map!\n"
+                 << *this;
+    llvm_unreachable("standard error assertion");
+  }
+#endif
+  unsigned constraintOffset = unsigned(kind) * 2 + 1;
+  return UseLifetimeConstraint(data[constraintOffset]);
+}
+
 /// A formal SIL reference to a value, suitable for use as a stored
 /// operand.
 class Operand {
@@ -413,10 +595,20 @@
   SILInstruction *getUser() { return Owner; }
   const SILInstruction *getUser() const { return Owner; }
 
-  /// getOperandNumber - Return which operand this is in the operand list of the
-  /// using instruction.
+  /// Return which operand this is in the operand list of the using instruction.
   unsigned getOperandNumber() const;
 
+  /// Return the static map of ValueOwnershipKinds that this operand can
+  /// potentially have to the UseLifetimeConstraint associated with that
+  /// ownership kind
+  ///
+  /// NOTE: This is implemented in OperandOwnershipKindMapClassifier.cpp.
+  ///
+  /// NOTE: The default argument isSubValue is a temporary staging flag that
+  /// will be removed once borrow scoping is checked by the normal verifier.
+  OperandOwnershipKindMap
+  getOwnershipKindMap(bool isForwardingSubValue = false) const;
+
 private:
   void removeFromCurrent() {
     if (!Back) return;
diff --git a/include/swift/SILOptimizer/Utils/LoadStoreOptUtils.h b/include/swift/SILOptimizer/Utils/LoadStoreOptUtils.h
index 177d531..5613af1 100644
--- a/include/swift/SILOptimizer/Utils/LoadStoreOptUtils.h
+++ b/include/swift/SILOptimizer/Utils/LoadStoreOptUtils.h
@@ -289,7 +289,6 @@
 //===----------------------------------------------------------------------===//
 //                            Load Store Location
 //===----------------------------------------------------------------------===//
-using LSLocationSet = llvm::DenseSet<LSLocation>;
 using LSLocationList = llvm::SmallVector<LSLocation, 8>;
 using LSLocationIndexMap = llvm::SmallDenseMap<LSLocation, unsigned, 32>;
 using LSLocationBaseMap = llvm::DenseMap<SILValue, LSLocation>;
@@ -357,7 +356,7 @@
 
   /// Given a set of locations derived from the same base, try to merge/reduce
   /// them into smallest number of LSLocations possible.
-  static bool reduce(LSLocation Base, SILModule *Mod, LSLocationSet &Locs);
+  static void reduce(LSLocation Base, SILModule *Mod, LSLocationList &Locs);
 
   /// Enumerate the given Mem LSLocation.
   static void enumerateLSLocation(SILModule *M, SILValue Mem,
diff --git a/include/swift/SILOptimizer/Utils/Local.h b/include/swift/SILOptimizer/Utils/Local.h
index 16c10b1..0224dd4 100644
--- a/include/swift/SILOptimizer/Utils/Local.h
+++ b/include/swift/SILOptimizer/Utils/Local.h
@@ -246,8 +246,8 @@
   /// In this case, if \p mode is AllowToModifyCFG, those critical edges are
   /// split, otherwise nothing is done and the returned \p Fr is not valid.
   ///
-  /// If \p DEBlocks is provided, all dead-end blocks are ignored. This prevents
-  /// unreachable-blocks to be included in the frontier.
+  /// If \p deadEndBlocks is provided, all dead-end blocks are ignored. This
+  /// prevents unreachable-blocks to be included in the frontier.
   bool computeFrontier(Frontier &Fr, Mode mode,
                        DeadEndBlocks *DEBlocks = nullptr);
 
diff --git a/lib/SIL/SILModule.cpp b/lib/SIL/SILModule.cpp
index 62ac387..ad2870c 100644
--- a/lib/SIL/SILModule.cpp
+++ b/lib/SIL/SILModule.cpp
@@ -660,6 +660,10 @@
   OptRecordRawStream = std::move(RawStream);
 }
 
+bool SILModule::isStdlibModule() const {
+  return TheSwiftModule->isStdlibModule();
+}
+
 SILProperty *SILProperty::create(SILModule &M,
                                  bool Serialized,
                                  AbstractStorageDecl *Decl,
diff --git a/lib/SIL/SILOwnershipVerifier.cpp b/lib/SIL/SILOwnershipVerifier.cpp
index 15ef4bc..6d6a157 100644
--- a/lib/SIL/SILOwnershipVerifier.cpp
+++ b/lib/SIL/SILOwnershipVerifier.cpp
@@ -12,7 +12,6 @@
 
 #define DEBUG_TYPE "sil-ownership-verifier"
 
-#include "UseOwnershipRequirement.h"
 #include "swift/AST/ASTContext.h"
 #include "swift/AST/AnyFunctionRef.h"
 #include "swift/AST/Decl.h"
@@ -137,66 +136,51 @@
 }
 
 //===----------------------------------------------------------------------===//
-//                      OwnershipCompatibilityUseChecker
+//                      OperandOwnershipKindClassifier
 //===----------------------------------------------------------------------===//
 
 namespace {
 
-struct OwnershipUseCheckerResult {
-  bool HasCompatibleOwnership;
-  bool ShouldCheckForDataflowViolations;
-
-  OwnershipUseCheckerResult(bool HasCompatibleOwnership,
-                            UseLifetimeConstraint OwnershipRequirement)
-      : HasCompatibleOwnership(HasCompatibleOwnership),
-        ShouldCheckForDataflowViolations(bool(OwnershipRequirement)) {}
-};
-
-class OwnershipCompatibilityUseChecker
-    : public SILInstructionVisitor<OwnershipCompatibilityUseChecker,
-                                   OwnershipUseCheckerResult> {
+class OperandOwnershipKindClassifier
+    : public SILInstructionVisitor<OperandOwnershipKindClassifier,
+                                   OperandOwnershipKindMap> {
 public:
+  using Map = OperandOwnershipKindMap;
+
 private:
-  LLVM_ATTRIBUTE_UNUSED
-  SILModule &Mod;
+  LLVM_ATTRIBUTE_UNUSED SILModule &mod;
 
-  const Operand &Op;
-  SILValue BaseValue;
-  ErrorBehaviorKind ErrorBehavior;
+  const Operand &op;
+  ErrorBehaviorKind errorBehavior;
+  bool checkingSubObject;
 
 public:
-  /// Create a new OwnershipCompatibilityUseChecker.
+  /// Create a new OperandOwnershipKindClassifier.
   ///
   /// In most cases, one should only pass in \p Op and \p BaseValue will be set
   /// to Op.get(). In cases where one is trying to verify subobjects, Op.get()
   /// should be the subobject and Value should be the parent object. An example
   /// of where one would want to do this is in the case of value projections
   /// like struct_extract.
-  OwnershipCompatibilityUseChecker(SILModule &M, const Operand &Op,
-                                   SILValue BaseValue,
-                                   ErrorBehaviorKind ErrorBehavior)
-      : Mod(M), Op(Op), BaseValue(BaseValue), ErrorBehavior(ErrorBehavior) {
-    assert((BaseValue == Op.get() ||
-            BaseValue.getOwnershipKind() == ValueOwnershipKind::Guaranteed) &&
-           "Guaranteed values are the only values allowed to have subobject");
-    // We only support subobjects on objects.
-    assert((BaseValue->getType().isObject() || !isCheckingSubObject()) &&
-           "Checking a subobject, but do not have an object base value?!");
-  }
+  OperandOwnershipKindClassifier(SILModule &mod, const Operand &op,
+                                 ErrorBehaviorKind errorBehavior,
+                                 bool checkingSubObject)
+      : mod(mod), op(op), errorBehavior(errorBehavior),
+        checkingSubObject(checkingSubObject) {}
 
-  bool isCheckingSubObject() const { return Op.get() != BaseValue; }
+  bool isCheckingSubObject() const { return checkingSubObject; }
 
-  SILValue getValue() const { return Op.get(); }
+  SILValue getValue() const { return op.get(); }
 
   ValueOwnershipKind getOwnershipKind() const {
-    assert(getValue().getOwnershipKind() == Op.get().getOwnershipKind() &&
+    assert(getValue().getOwnershipKind() == op.get().getOwnershipKind() &&
            "Expected ownership kind of parent value and operand");
     return getValue().getOwnershipKind();
   }
 
-  unsigned getOperandIndex() const { return Op.getOperandNumber(); }
+  unsigned getOperandIndex() const { return op.getOperandNumber(); }
 
-  SILType getType() const { return Op.get()->getType(); }
+  SILType getType() const { return op.get()->getType(); }
 
   bool compatibleWithOwnership(ValueOwnershipKind Kind) const {
     return getOwnershipKind().isCompatibleWith(Kind);
@@ -213,73 +197,26 @@
       getOwnershipKind() == ValueOwnershipKind::Any;
   }
 
-  /// Depending on our initialization, either return false or call Func and
-  /// throw an error.
-  bool handleError(llvm::function_ref<void()> &&MessagePrinterFunc) const {
-    if (ErrorBehavior.shouldPrintMessage()) {
-      MessagePrinterFunc();
-    }
-
-    if (ErrorBehavior.shouldReturnFalse()) {
-      return false;
-    }
-
-    assert(ErrorBehavior.shouldAssert() && "At this point, we should assert");
-    llvm_unreachable("triggering standard assertion failure routine");
-  }
-
-  OwnershipUseCheckerResult visitForwardingInst(SILInstruction *I,
-                                                ArrayRef<Operand> Ops);
-  OwnershipUseCheckerResult visitForwardingInst(SILInstruction *I) {
+  OperandOwnershipKindMap visitForwardingInst(SILInstruction *I,
+                                              ArrayRef<Operand> Ops);
+  OperandOwnershipKindMap visitForwardingInst(SILInstruction *I) {
     return visitForwardingInst(I, I->getAllOperands());
   }
 
-  /// Visit a terminator instance that performs a transform like
-  /// operation. E.x.: switch_enum, checked_cast_br. This does not include br or
-  /// cond_br.
-  OwnershipUseCheckerResult visitTransformingTerminatorInst(TermInst *TI);
-
-  OwnershipUseCheckerResult
-  visitEnumArgument(EnumDecl *E, ValueOwnershipKind RequiredConvention);
-  OwnershipUseCheckerResult
+  OperandOwnershipKindMap
+  visitEnumArgument(ValueOwnershipKind RequiredConvention);
+  OperandOwnershipKindMap
   visitApplyParameter(ValueOwnershipKind RequiredConvention,
                       UseLifetimeConstraint Requirement);
-  OwnershipUseCheckerResult
-  visitFullApply(FullApplySite apply);
+  OperandOwnershipKindMap visitFullApply(FullApplySite apply);
 
-  /// Check if \p User as compatible ownership with the SILValue that we are
-  /// checking.
-  ///
-  /// \returns true if the user is a use that must be checked for dataflow
-  /// violations.
-  bool check(SILInstruction *User) {
-    auto Result = visit(User);
-    if (!Result.HasCompatibleOwnership) {
-      return handleError([&]() {
-        llvm::errs() << "Function: '" << User->getFunction()->getName() << "'\n"
-                     << "Have operand with incompatible ownership?!\n"
-                     << "Value: " << *getValue() << "BaseValue: " << *BaseValue
-                     << "User: " << *User << "Conv: " << getOwnershipKind()
-                     << "\n\n";
-      });
-    }
-
-    assert((!Result.ShouldCheckForDataflowViolations ||
-            !isAddressOrTrivialType()) &&
-           "Address or trivial types should never be checked for dataflow "
-           "violations");
-
-    return Result.ShouldCheckForDataflowViolations;
-  }
-
-  OwnershipUseCheckerResult visitCallee(CanSILFunctionType SubstCalleeType);
-  OwnershipUseCheckerResult
+  OperandOwnershipKindMap visitCallee(CanSILFunctionType SubstCalleeType);
+  OperandOwnershipKindMap
   checkTerminatorArgumentMatchesDestBB(SILBasicBlock *DestBB, unsigned OpIndex);
 
 // Create declarations for all instructions, so we get a warning at compile
 // time if any instructions do not have an implementation.
-#define INST(Id, Parent) \
-  OwnershipUseCheckerResult visit##Id(Id *);
+#define INST(Id, Parent) OperandOwnershipKindMap visit##Id(Id *);
 #include "swift/SIL/SILNodes.def"
 };
 
@@ -288,9 +225,9 @@
 /// Implementation for instructions without operands. These should never be
 /// visited.
 #define NO_OPERAND_INST(INST)                                                  \
-  OwnershipUseCheckerResult                                                    \
-      OwnershipCompatibilityUseChecker::visit##INST##Inst(INST##Inst *I) {     \
-    assert(I->getNumOperands() == 0 &&                                         \
+  OperandOwnershipKindMap OperandOwnershipKindClassifier::visit##INST##Inst(   \
+      INST##Inst *i) {                                                         \
+    assert(i->getNumOperands() == 0 &&                                         \
            "Expected instruction without operands?!");                         \
     llvm_unreachable("Instruction without operand can not be compatible with " \
                      "any def's OwnershipValueKind");                          \
@@ -320,16 +257,12 @@
 
 /// Instructions whose arguments are always compatible with one convention.
 #define CONSTANT_OWNERSHIP_INST(OWNERSHIP, USE_LIFETIME_CONSTRAINT, INST)      \
-  OwnershipUseCheckerResult                                                    \
-      OwnershipCompatibilityUseChecker::visit##INST##Inst(INST##Inst *I) {     \
-    assert(I->getNumOperands() && "Expected to have non-zero operands");       \
-    if (ValueOwnershipKind::OWNERSHIP == ValueOwnershipKind::Trivial) {        \
-      assert(isAddressOrTrivialType() &&                                       \
-             "Trivial ownership requires a trivial type or an address");       \
-    }                                                                          \
-                                                                               \
-    return {compatibleWithOwnership(ValueOwnershipKind::OWNERSHIP),            \
-            UseLifetimeConstraint::USE_LIFETIME_CONSTRAINT};                   \
+  OperandOwnershipKindMap OperandOwnershipKindClassifier::visit##INST##Inst(   \
+      INST##Inst *i) {                                                         \
+    assert(i->getNumOperands() && "Expected to have non-zero operands");       \
+    return Map::compatibilityMap(                                              \
+        ValueOwnershipKind::OWNERSHIP,                                         \
+        UseLifetimeConstraint::USE_LIFETIME_CONSTRAINT);                       \
   }
 CONSTANT_OWNERSHIP_INST(Guaranteed, MustBeLive, IsEscapingClosure)
 CONSTANT_OWNERSHIP_INST(Guaranteed, MustBeLive, RefElementAddr)
@@ -413,19 +346,13 @@
 /// Instructions whose arguments are always compatible with one convention.
 #define CONSTANT_OR_TRIVIAL_OWNERSHIP_INST(OWNERSHIP, USE_LIFETIME_CONSTRAINT, \
                                            INST)                               \
-  OwnershipUseCheckerResult                                                    \
-      OwnershipCompatibilityUseChecker::visit##INST##Inst(INST##Inst *I) {     \
-    assert(I->getNumOperands() && "Expected to have non-zero operands");       \
-    if (ValueOwnershipKind::OWNERSHIP == ValueOwnershipKind::Trivial) {        \
-      assert(isAddressOrTrivialType() &&                                       \
-             "Trivial ownership requires a trivial type or an address");       \
-    }                                                                          \
-                                                                               \
-    if (compatibleWithOwnership(ValueOwnershipKind::Trivial)) {                \
-      return {true, UseLifetimeConstraint::MustBeLive};                        \
-    }                                                                          \
-    return {compatibleWithOwnership(ValueOwnershipKind::OWNERSHIP),            \
-            UseLifetimeConstraint::USE_LIFETIME_CONSTRAINT};                   \
+  OperandOwnershipKindMap OperandOwnershipKindClassifier::visit##INST##Inst(   \
+      INST##Inst *i) {                                                         \
+    assert(i->getNumOperands() && "Expected to have non-zero operands");       \
+    return Map::compatibilityMap(                                              \
+        {{ValueOwnershipKind::Trivial, UseLifetimeConstraint::MustBeLive},     \
+         {ValueOwnershipKind::OWNERSHIP,                                       \
+          UseLifetimeConstraint::USE_LIFETIME_CONSTRAINT}});                   \
   }
 CONSTANT_OR_TRIVIAL_OWNERSHIP_INST(Owned, MustBeInvalidated,
                                    CheckedCastValueBranch)
@@ -438,9 +365,9 @@
 #undef CONSTANT_OR_TRIVIAL_OWNERSHIP_INST
 
 #define ACCEPTS_ANY_OWNERSHIP_INST(INST)                                       \
-  OwnershipUseCheckerResult                                                    \
-      OwnershipCompatibilityUseChecker::visit##INST##Inst(INST##Inst *I) {     \
-    return {true, UseLifetimeConstraint::MustBeLive};                          \
+  OperandOwnershipKindMap OperandOwnershipKindClassifier::visit##INST##Inst(   \
+      INST##Inst *I) {                                                         \
+    return Map::allLive();                                                     \
   }
 ACCEPTS_ANY_OWNERSHIP_INST(BeginBorrow)
 ACCEPTS_ANY_OWNERSHIP_INST(CopyValue)
@@ -460,15 +387,14 @@
 // Trivial if trivial typed, otherwise must accept owned?
 #define ACCEPTS_ANY_NONTRIVIAL_OWNERSHIP_OR_METATYPE(USE_LIFETIME_CONSTRAINT,  \
                                                      INST)                     \
-  OwnershipUseCheckerResult                                                    \
-      OwnershipCompatibilityUseChecker::visit##INST##Inst(INST##Inst *I) {     \
+  OperandOwnershipKindMap OperandOwnershipKindClassifier::visit##INST##Inst(   \
+      INST##Inst *I) {                                                         \
     assert(I->getNumOperands() && "Expected to have non-zero operands");       \
     if (getType().is<AnyMetatypeType>()) {                                     \
-      return {true, UseLifetimeConstraint::MustBeLive};                        \
+      return Map::compatibilityMap(ValueOwnershipKind::Trivial,                \
+                                   UseLifetimeConstraint::MustBeLive);         \
     }                                                                          \
-    bool compatible = hasExactOwnership(ValueOwnershipKind::Any) ||            \
-                      !compatibleWithOwnership(ValueOwnershipKind::Trivial);   \
-    return {compatible, UseLifetimeConstraint::USE_LIFETIME_CONSTRAINT};       \
+    return Map::compatibleWithAllExcept(ValueOwnershipKind::Trivial);          \
   }
 ACCEPTS_ANY_NONTRIVIAL_OWNERSHIP_OR_METATYPE(MustBeLive, ClassMethod)
 ACCEPTS_ANY_NONTRIVIAL_OWNERSHIP_OR_METATYPE(MustBeLive, ObjCMethod)
@@ -478,12 +404,10 @@
 
 // Trivial if trivial typed, otherwise must accept owned?
 #define ACCEPTS_ANY_NONTRIVIAL_OWNERSHIP(USE_LIFETIME_CONSTRAINT, INST)        \
-  OwnershipUseCheckerResult                                                    \
-      OwnershipCompatibilityUseChecker::visit##INST##Inst(INST##Inst *I) {     \
+  OperandOwnershipKindMap OperandOwnershipKindClassifier::visit##INST##Inst(   \
+      INST##Inst *I) {                                                         \
     assert(I->getNumOperands() && "Expected to have non-zero operands");       \
-    bool compatible = hasExactOwnership(ValueOwnershipKind::Any) ||            \
-                      !compatibleWithOwnership(ValueOwnershipKind::Trivial);   \
-    return {compatible, UseLifetimeConstraint::USE_LIFETIME_CONSTRAINT};       \
+    return Map::compatibleWithAllExcept(ValueOwnershipKind::Trivial);          \
   }
 ACCEPTS_ANY_NONTRIVIAL_OWNERSHIP(MustBeLive, BridgeObjectToWord)
 ACCEPTS_ANY_NONTRIVIAL_OWNERSHIP(MustBeLive, ClassifyBridgeObject)
@@ -506,53 +430,47 @@
 #include "swift/AST/ReferenceStorage.def"
 #undef ACCEPTS_ANY_NONTRIVIAL_OWNERSHIP
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitForwardingInst(SILInstruction *I, ArrayRef<Operand> Ops) {
-  assert(I->getNumOperands() && "Expected to have non-zero operands");
-  assert(isOwnershipForwardingInst(I) &&
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitForwardingInst(SILInstruction *i,
+                                                    ArrayRef<Operand> ops) {
+  assert(i->getNumOperands() && "Expected to have non-zero operands");
+  assert(isOwnershipForwardingInst(i) &&
          "Expected to have an ownership forwarding inst");
 
-  // Find the first index where we have a trivial value.
-  auto Iter = find_if(Ops, [&I](const Operand &Op) -> bool {
-    if (I->isTypeDependentOperand(Op))
+  // Find the first index where we have a non-trivial value.
+  auto iter = find_if(ops, [&i](const Operand &op) -> bool {
+    if (i->isTypeDependentOperand(op))
       return false;
-    return Op.get().getOwnershipKind() != ValueOwnershipKind::Trivial;
+    return op.get().getOwnershipKind() != ValueOwnershipKind::Trivial;
   });
 
-  // All trivial.
-  if (Iter == Ops.end()) {
-    return {compatibleWithOwnership(ValueOwnershipKind::Trivial),
-            UseLifetimeConstraint::MustBeLive};
+  // If we do not find a non-trivial value, then we know for sure that we have a
+  // trivial value.
+  if (iter == ops.end()) {
+    return Map::compatibilityMap(ValueOwnershipKind::Trivial,
+                                 UseLifetimeConstraint::MustBeLive);
   }
 
-  unsigned Index = std::distance(Ops.begin(), Iter);
-  ValueOwnershipKind Base = Ops[Index].get().getOwnershipKind();
+  // Ok, we have at least a single non-trivial value. Grab the type of the
+  // operand and see if it is trivial or non-trivial. If the type of the operand
+  // is trivial, then return that we accept trivial here. Otherwise, return the
+  // base ownership kind.
+  if (getType().isTrivial(mod))
+    return Map::compatibilityMap(ValueOwnershipKind::Trivial,
+                                 UseLifetimeConstraint::MustBeLive);
 
-  for (const Operand &Op : Ops.slice(Index + 1)) {
-    if (I->isTypeDependentOperand(Op))
-      continue;
-    auto OpKind = Op.get().getOwnershipKind();
-    if (OpKind.merge(ValueOwnershipKind::Trivial))
-      continue;
-
-    auto MergedValue = Base.merge(OpKind.Value);
-    if (!MergedValue.hasValue()) {
-      return {false, UseLifetimeConstraint::MustBeInvalidated};
-    }
-    Base = MergedValue.getValue();
-  }
-
-  // We only need to treat a forwarded instruction as a lifetime ending use of
-  // it is owned.
-  auto lifetimeConstraint = hasExactOwnership(ValueOwnershipKind::Owned)
-                                ? UseLifetimeConstraint::MustBeInvalidated
-                                : UseLifetimeConstraint::MustBeLive;
-  return {true, lifetimeConstraint};
+  // Otherwise, return the value ownership kind and forwarding lifetime
+  // constraint of the first non-trivial operand. This will ensure that all
+  // non-trivial operands have the same ownership kind.
+  unsigned index = std::distance(ops.begin(), iter);
+  ValueOwnershipKind kind = ops[index].get().getOwnershipKind();
+  auto lifetimeConstraint = kind.getForwardingLifetimeConstraint();
+  return Map::compatibilityMap(kind, lifetimeConstraint);
 }
 
 #define FORWARD_ANY_OWNERSHIP_INST(INST)                                       \
-  OwnershipUseCheckerResult                                                    \
-      OwnershipCompatibilityUseChecker::visit##INST##Inst(INST##Inst *I) {     \
+  OperandOwnershipKindMap OperandOwnershipKindClassifier::visit##INST##Inst(   \
+      INST##Inst *I) {                                                         \
     return visitForwardingInst(I);                                             \
   }
 FORWARD_ANY_OWNERSHIP_INST(Tuple)
@@ -575,189 +493,246 @@
 // An instruction that forwards a constant ownership or trivial ownership.
 #define FORWARD_CONSTANT_OR_TRIVIAL_OWNERSHIP_INST(                            \
     OWNERSHIP, USE_LIFETIME_CONSTRAINT, INST)                                  \
-  OwnershipUseCheckerResult                                                    \
-      OwnershipCompatibilityUseChecker::visit##INST##Inst(INST##Inst *I) {     \
+  OperandOwnershipKindMap OperandOwnershipKindClassifier::visit##INST##Inst(   \
+      INST##Inst *I) {                                                         \
     assert(I->getNumOperands() && "Expected to have non-zero operands");       \
     assert(isGuaranteedForwardingInst(I) &&                                    \
            "Expected an ownership forwarding inst");                           \
-    if (ValueOwnershipKind::OWNERSHIP != ValueOwnershipKind::Trivial &&        \
-        hasExactOwnership(ValueOwnershipKind::Trivial)) {                      \
-      assert(isAddressOrTrivialType() &&                                       \
-             "Trivial ownership requires a trivial type or an address");       \
-      return {true, UseLifetimeConstraint::MustBeLive};                        \
-    }                                                                          \
-    if (ValueOwnershipKind::OWNERSHIP == ValueOwnershipKind::Trivial) {        \
-      assert(isAddressOrTrivialType() &&                                       \
-             "Trivial ownership requires a trivial type or an address");       \
-    }                                                                          \
-                                                                               \
-    return {compatibleWithOwnership(ValueOwnershipKind::OWNERSHIP),            \
-            UseLifetimeConstraint::USE_LIFETIME_CONSTRAINT};                   \
+    OperandOwnershipKindMap map;                                               \
+    map.add(ValueOwnershipKind::Trivial, UseLifetimeConstraint::MustBeLive);   \
+    map.addCompatibilityConstraint(                                            \
+        ValueOwnershipKind::OWNERSHIP,                                         \
+        UseLifetimeConstraint::USE_LIFETIME_CONSTRAINT);                       \
+    return map;                                                                \
   }
 FORWARD_CONSTANT_OR_TRIVIAL_OWNERSHIP_INST(Guaranteed, MustBeLive, TupleExtract)
 FORWARD_CONSTANT_OR_TRIVIAL_OWNERSHIP_INST(Guaranteed, MustBeLive,
                                            StructExtract)
 #undef CONSTANT_OR_TRIVIAL_OWNERSHIP_INST
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitDeallocPartialRefInst(
-    DeallocPartialRefInst *I) {
-  if (getValue() == I->getInstance()) {
-    return {compatibleWithOwnership(ValueOwnershipKind::Owned),
-            UseLifetimeConstraint::MustBeInvalidated};
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitDeallocPartialRefInst(
+    DeallocPartialRefInst *i) {
+  if (getValue() == i->getInstance()) {
+    return Map::compatibilityMap(ValueOwnershipKind::Owned,
+                                 UseLifetimeConstraint::MustBeInvalidated);
   }
 
-  return {compatibleWithOwnership(ValueOwnershipKind::Trivial),
-          UseLifetimeConstraint::MustBeLive};
+  return Map::compatibilityMap(ValueOwnershipKind::Trivial,
+                               UseLifetimeConstraint::MustBeLive);
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitSelectEnumInst(SelectEnumInst *I) {
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitSelectEnumInst(SelectEnumInst *I) {
   if (getValue() == I->getEnumOperand()) {
-    return {true, UseLifetimeConstraint::MustBeLive};
+    return Map::allLive();
   }
 
   return visitForwardingInst(I, I->getAllOperands().drop_front());
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitAllocRefInst(AllocRefInst *I) {
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitAllocRefInst(AllocRefInst *I) {
   assert(I->getNumOperands() != 0
          && "If we reach this point, we must have a tail operand");
-  return {compatibleWithOwnership(ValueOwnershipKind::Trivial),
-          UseLifetimeConstraint::MustBeLive};
+  return Map::compatibilityMap(ValueOwnershipKind::Trivial,
+                               UseLifetimeConstraint::MustBeLive);
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitAllocRefDynamicInst(
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitAllocRefDynamicInst(
     AllocRefDynamicInst *I) {
   assert(I->getNumOperands() != 0 &&
          "If we reach this point, we must have a tail operand");
-  return {compatibleWithOwnership(ValueOwnershipKind::Trivial),
-          UseLifetimeConstraint::MustBeLive};
+  return Map::compatibilityMap(ValueOwnershipKind::Trivial,
+                               UseLifetimeConstraint::MustBeLive);
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::checkTerminatorArgumentMatchesDestBB(
-    SILBasicBlock *DestBB, unsigned OpIndex) {
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::checkTerminatorArgumentMatchesDestBB(
+    SILBasicBlock *destBB, unsigned opIndex) {
   // Grab the ownership kind of the destination block.
-  ValueOwnershipKind DestBlockArgOwnershipKind =
-      DestBB->getArgument(OpIndex)->getOwnershipKind();
+  ValueOwnershipKind destBlockArgOwnershipKind =
+      destBB->getArgument(opIndex)->getOwnershipKind();
 
   // Then if we do not have an enum, make sure that the conventions match.
-  EnumDecl *E = getType().getEnumOrBoundGenericEnum();
-  if (!E) {
-    bool matches = compatibleWithOwnership(DestBlockArgOwnershipKind);
-    auto lifetimeConstraint = hasExactOwnership(ValueOwnershipKind::Owned)
-                                  ? UseLifetimeConstraint::MustBeInvalidated
-                                  : UseLifetimeConstraint::MustBeLive;
-    return {matches, lifetimeConstraint};
+  if (!getType().getEnumOrBoundGenericEnum()) {
+    auto lifetimeConstraint =
+        destBlockArgOwnershipKind.getForwardingLifetimeConstraint();
+    return Map::compatibilityMap(destBlockArgOwnershipKind, lifetimeConstraint);
   }
 
-  return visitEnumArgument(E, DestBlockArgOwnershipKind);
+  // Otherwise, we need to properly handle the sum type nature of enum
+  // arguments.
+  return visitEnumArgument(destBlockArgOwnershipKind);
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitBranchInst(BranchInst *BI) {
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitBranchInst(BranchInst *BI) {
   return checkTerminatorArgumentMatchesDestBB(BI->getDestBB(),
                                               getOperandIndex());
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitCondBranchInst(CondBranchInst *CBI) {
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitCondBranchInst(CondBranchInst *cbi) {
   // If our conditional branch is the condition, it is trivial. Check that the
   // ownership kind is trivial.
-  if (CBI->isConditionOperandIndex(getOperandIndex()))
-    return {compatibleWithOwnership(ValueOwnershipKind::Trivial),
-            UseLifetimeConstraint::MustBeLive};
+  if (cbi->isConditionOperandIndex(getOperandIndex()))
+    return Map::compatibilityMap(ValueOwnershipKind::Trivial,
+                                 UseLifetimeConstraint::MustBeLive);
 
-  // Otherwise, make sure that our operand matches the
-  if (CBI->isTrueOperandIndex(getOperandIndex())) {
-    unsigned TrueOffset = 1;
-    return checkTerminatorArgumentMatchesDestBB(CBI->getTrueBB(),
-                                                getOperandIndex() - TrueOffset);
+  // Otherwise, make sure that our operand matches the ownership of the relevant
+  // argument.
+  //
+  // TODO: Use more updated APIs here to get the operands/etc.
+  if (cbi->isTrueOperandIndex(getOperandIndex())) {
+    unsigned trueOffset = 1;
+    return checkTerminatorArgumentMatchesDestBB(cbi->getTrueBB(),
+                                                getOperandIndex() - trueOffset);
   }
 
-  assert(CBI->isFalseOperandIndex(getOperandIndex()) &&
+  assert(cbi->isFalseOperandIndex(getOperandIndex()) &&
          "If an operand is not the condition index or a true operand index, it "
          "must be a false operand index");
-  unsigned FalseOffset = 1 + CBI->getTrueOperands().size();
-  return checkTerminatorArgumentMatchesDestBB(CBI->getFalseBB(),
-                                              getOperandIndex() - FalseOffset);
+  unsigned falseOffset = 1 + cbi->getTrueOperands().size();
+  return checkTerminatorArgumentMatchesDestBB(cbi->getFalseBB(),
+                                              getOperandIndex() - falseOffset);
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitSwitchEnumInst(SwitchEnumInst *SEI) {
-  return visitTransformingTerminatorInst(SEI);
-}
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitSwitchEnumInst(SwitchEnumInst *sei) {
+  auto opTy = sei->getOperand()->getType();
+  auto &mod = sei->getModule();
+  // If our passed in type is trivial, we shouldn't have any non-trivial
+  // successors. Just bail early returning trivial.
+  if (opTy.isTrivial(mod))
+    return Map::compatibilityMap(ValueOwnershipKind::Trivial,
+                                 UseLifetimeConstraint::MustBeLive);
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitCheckedCastBranchInst(
-    CheckedCastBranchInst *SEI) {
-  return visitTransformingTerminatorInst(SEI);
-}
+  // Otherwise, go through the cases of the enum. If we have any cases with
+  // trivial payload or no payload cases, add trivial as a base ownership kind
+  // we can accept.
+  OperandOwnershipKindMap map;
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitTransformingTerminatorInst(
-    TermInst *TI) {
-  // If our operand was trivial, return early.
-  if (compatibleWithOwnership(ValueOwnershipKind::Trivial))
-    return {true, UseLifetimeConstraint::MustBeLive};
+  bool foundNonTrivialCase = false;
 
-  // Then we need to go through all of our destinations and make sure that if
-  // they have a payload, the payload's convention matches our
-  // convention.
-  //
-  // *NOTE* we assume that all of our types line up and are checked by the
-  // normal verifier.
-  for (auto *Succ : TI->getParent()->getSuccessorBlocks()) {
-    // This must be a no-payload case... continue.
-    if (Succ->args_size() == 0)
+  auto *enumDecl = opTy.getEnumOrBoundGenericEnum();
+  assert(enumDecl);
+  for (auto *eltDecl : enumDecl->getAllElements()) {
+    // If we have a no-payload case add that we support trivial and continue.
+    if (!eltDecl->hasAssociatedValues()) {
+      map.addCompatibilityConstraint(ValueOwnershipKind::Trivial,
+                                     UseLifetimeConstraint::MustBeLive);
       continue;
+    }
 
-    // If we have a trivial value or a value with ownership kind that matches
-    // the switch_enum, then continue.
-    auto OwnershipKind = Succ->getArgument(0)->getOwnershipKind();
-    if (OwnershipKind == ValueOwnershipKind::Trivial ||
-        compatibleWithOwnership(OwnershipKind))
+    // If we have a completely trivial payload case, then add that we support
+    // trivial and continue.
+    if (opTy.getEnumElementType(eltDecl, mod).isTrivial(mod)) {
+      map.addCompatibilityConstraint(ValueOwnershipKind::Trivial,
+                                     UseLifetimeConstraint::MustBeLive);
       continue;
+    }
 
-    // Otherwise, emit an error.
-    handleError([&]() {
-      llvm::errs()
-          << "Function: '" << Succ->getParent()->getName() << "'\n"
-          << "Error! Argument ownership kind does not match terminator!\n"
-          << "Terminator: " << *TI << "Argument: " << *Succ->getArgument(0)
-          << "Expected convention: " << getOwnershipKind() << ".\n"
-          << "Actual convention:   " << OwnershipKind << '\n'
-          << '\n';
-    });
+    // Otherwise, we have a non-trivial case. Set foundNonTrivialCase to
+    // true. We will need to check the arguments of the switch_enum's successors
+    // for the ownership kind that we can accept.
+    foundNonTrivialCase = true;
   }
 
-  // Finally, if everything lines up, emit that we match and are a lifetime
-  // ending point if we are owned.
-  auto lifetimeConstraint = hasExactOwnership(ValueOwnershipKind::Owned)
-                                ? UseLifetimeConstraint::MustBeInvalidated
-                                : UseLifetimeConstraint::MustBeLive;
-  return {true, lifetimeConstraint};
+  // If we didn't find a non-trivial case, return the map we have constructed so
+  // far.
+  if (!foundNonTrivialCase)
+    return map;
+
+  // Otherwise, we want to find the ownership constraint of our successor
+  // arguments.
+  Optional<ValueOwnershipKind> nonTrivialKind;
+  for (auto argArray : sei->getSuccessorBlockArguments()) {
+    if (argArray.empty())
+      continue;
+    SILValue arg = argArray[getOperandIndex()];
+    if (arg->getType().isTrivial(mod))
+      continue;
+
+    // If we haven't found a non-trivial kind yet, stash the kind we find.
+    if (!nonTrivialKind) {
+      nonTrivialKind = arg.getOwnershipKind();
+      continue;
+    }
+
+    // Otherwise if we /do/ have a non trivial kind and the argument's ownership
+    // kind is compatible, merge in case the first value we saw had Any
+    // ownership.
+    auto newKind = nonTrivialKind->merge(arg.getOwnershipKind());
+    if (newKind) {
+      nonTrivialKind = newKind;
+      continue;
+    }
+
+    // Otherwise, we have inconsistent ownership in between our successors. To
+    // be sure that we error, return an empty map.
+    return Map();
+  }
+
+  // We should never have an enum with a non-trivial case where we do not have
+  // at least one successor with a proper ownership qualifier since we either
+  // switch over the entire enum implying we visit that case, or we go through
+  // the default which will have our enum type as its type and thus some form of
+  // non-trivial ownership. So it is correct to use the optional here without
+  // checking.
+  auto lifetimeConstraint = nonTrivialKind->getForwardingLifetimeConstraint();
+  map.addCompatibilityConstraint(*nonTrivialKind, lifetimeConstraint);
+
+  return map;
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitReturnInst(ReturnInst *RI) {
-  SILModule &M = RI->getModule();
-  bool IsTrivial = RI->getOperand()->getType().isTrivial(M);
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitCheckedCastBranchInst(
+    CheckedCastBranchInst *ccbi) {
+  Optional<OperandOwnershipKindMap> map;
+  for (auto argArray : ccbi->getSuccessorBlockArguments()) {
+    assert(!argArray.empty());
+
+    auto argOwnershipKind = argArray[getOperandIndex()]->getOwnershipKind();
+    // If we do not have a map yet, initialize it and continue.
+    if (!map) {
+      auto lifetimeConstraint =
+          argOwnershipKind.getForwardingLifetimeConstraint();
+      map = Map::compatibilityMap(argOwnershipKind, lifetimeConstraint);
+      continue;
+    }
+
+    // Otherwise, make sure that we can accept the rest of our
+    // arguments. If not, we return an empty ownership kind to make
+    // sure that we flag everything as an error.
+    if (map->canAcceptKind(argOwnershipKind)) {
+      continue;
+    }
+
+    return OperandOwnershipKindMap();
+  }
+
+  return map.getValue();
+}
+
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitReturnInst(ReturnInst *RI) {
+  bool IsTrivial = RI->getOperand()->getType().isTrivial(mod);
   SILFunctionConventions fnConv = RI->getFunction()->getConventions();
   auto Results = fnConv.getDirectSILResults();
+  // FIXME: Shouldn't we return an empty OperandOwnershipKindMap here if we do
+  // not have any results?
   if (Results.empty() || IsTrivial) {
-    return {compatibleWithOwnership(ValueOwnershipKind::Trivial),
-            UseLifetimeConstraint::MustBeLive};
+    return Map::compatibilityMap(ValueOwnershipKind::Trivial,
+                                 UseLifetimeConstraint::MustBeLive);
   }
 
   CanGenericSignature Sig = fnConv.funcTy->getGenericSignature();
 
   // Find the first index where we have a trivial value.
-  auto Iter = find_if(Results, [&M, &Sig](const SILResultInfo &Info) -> bool {
-    return Info.getOwnershipKind(M, Sig) != ValueOwnershipKind::Trivial;
+  auto Iter = find_if(Results, [this, &Sig](const SILResultInfo &Info) -> bool {
+    return Info.getOwnershipKind(mod, Sig) != ValueOwnershipKind::Trivial;
   });
 
   // If we have all trivial, then we must be trivial. Why wasn't our original
@@ -766,115 +741,111 @@
   if (Iter == Results.end())
     llvm_unreachable("Should have already checked a trivial type?!");
 
-  ValueOwnershipKind Base = Iter->getOwnershipKind(M, Sig);
+  ValueOwnershipKind Base = Iter->getOwnershipKind(mod, Sig);
 
   for (const SILResultInfo &ResultInfo :
        SILFunctionConventions::DirectSILResultRange(std::next(Iter),
                                                     Results.end())) {
-    auto RKind = ResultInfo.getOwnershipKind(M, Sig);
+    auto RKind = ResultInfo.getOwnershipKind(mod, Sig);
     // Ignore trivial types.
     if (RKind.merge(ValueOwnershipKind::Trivial))
       continue;
 
     auto MergedValue = Base.merge(RKind);
     // If we fail to merge all types in, bail. We can not come up with a proper
-    // result type.
-    if (!MergedValue.hasValue()) {
-      return {false, UseLifetimeConstraint::MustBeLive};
-    }
+    // result type. We assert here since this is a hard error in the normal
+    // SILVerifier since the return type of the function would not match its
+    // terminator.
+    assert(MergedValue.hasValue() &&
+           "Failed to merge all types in on a return?!");
     // In case Base is Any.
     Base = MergedValue.getValue();
   }
 
-  if (auto *E = getType().getEnumOrBoundGenericEnum()) {
-    return visitEnumArgument(E, Base);
+  if (getType().getEnumOrBoundGenericEnum()) {
+    return visitEnumArgument(Base);
   }
 
-  return {compatibleWithOwnership(Base),
-          UseLifetimeConstraint::MustBeInvalidated};
+  return Map::compatibilityMap(Base, UseLifetimeConstraint::MustBeInvalidated);
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitEndBorrowInst(EndBorrowInst *I) {
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitEndBorrowInst(EndBorrowInst *I) {
   // If we are checking a subobject, make sure that we are from a guaranteed
   // basic block argument.
   if (isCheckingSubObject()) {
-    auto *phiArg = cast<SILPhiArgument>(Op.get());
+    auto *phiArg = cast<SILPhiArgument>(op.get());
     (void)phiArg;
-    assert(phiArg->getOwnershipKind() == ValueOwnershipKind::Guaranteed &&
-           "Expected an end_borrow paired with an argument.");
-    return {true, UseLifetimeConstraint::MustBeLive};
+    return Map::compatibilityMap(ValueOwnershipKind::Guaranteed,
+                                 UseLifetimeConstraint::MustBeLive);
   }
 
   /// An end_borrow is modeled as invalidating the guaranteed value preventing
   /// any further uses of the value.
-  return {compatibleWithOwnership(ValueOwnershipKind::Guaranteed),
-          UseLifetimeConstraint::MustBeInvalidated};
+  return Map::compatibilityMap(ValueOwnershipKind::Guaranteed,
+                               UseLifetimeConstraint::MustBeInvalidated);
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitThrowInst(ThrowInst *I) {
-  return {compatibleWithOwnership(ValueOwnershipKind::Owned),
-          UseLifetimeConstraint::MustBeInvalidated};
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitThrowInst(ThrowInst *I) {
+  return Map::compatibilityMap(ValueOwnershipKind::Owned,
+                               UseLifetimeConstraint::MustBeInvalidated);
 }
 
-#define NEVER_LOADABLE_CHECKED_REF_STORAGE(Name, ...) \
-OwnershipUseCheckerResult \
-OwnershipCompatibilityUseChecker::visitStore##Name##Inst(Store##Name##Inst *I){\
-  /* A store instruction implies that the value to be stored to be live, */ \
-  /* but it does not touch the strong reference count of the value. */ \
-  if (getValue() == I->getSrc()) \
-    return {true, UseLifetimeConstraint::MustBeLive}; \
-  return {compatibleWithOwnership(ValueOwnershipKind::Trivial), \
-          UseLifetimeConstraint::MustBeLive}; \
-}
+#define NEVER_LOADABLE_CHECKED_REF_STORAGE(Name, ...)                          \
+  OperandOwnershipKindMap                                                      \
+      OperandOwnershipKindClassifier::visitStore##Name##Inst(                  \
+          Store##Name##Inst *I) {                                              \
+    /* A store instruction implies that the value to be stored to be live, */  \
+    /* but it does not touch the strong reference count of the value. We */    \
+    /* also just care about liveness for the dest. So just match everything */ \
+    /* as must be live. */                                                     \
+    return Map::allLive();                                                     \
+  }
 #define SOMETIMES_LOADABLE_CHECKED_REF_STORAGE(Name, ...) \
   NEVER_LOADABLE_CHECKED_REF_STORAGE(Name, "...")
 #include "swift/AST/ReferenceStorage.def"
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitStoreBorrowInst(StoreBorrowInst *I) {
-  if (getValue() == I->getSrc())
-    return {compatibleWithOwnership(ValueOwnershipKind::Guaranteed),
-            UseLifetimeConstraint::MustBeLive};
-  return {compatibleWithOwnership(ValueOwnershipKind::Trivial),
-          UseLifetimeConstraint::MustBeLive};
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitStoreBorrowInst(StoreBorrowInst *I) {
+  if (getValue() == I->getSrc()) {
+    return Map::compatibilityMap(ValueOwnershipKind::Guaranteed,
+                                 UseLifetimeConstraint::MustBeLive);
+  }
+  return Map::compatibilityMap(ValueOwnershipKind::Trivial,
+                               UseLifetimeConstraint::MustBeLive);
 }
 
 // FIXME: Why not use SILArgumentConvention here?
-OwnershipUseCheckerResult OwnershipCompatibilityUseChecker::visitCallee(
-    CanSILFunctionType SubstCalleeType) {
-  ParameterConvention Conv = SubstCalleeType->getCalleeConvention();
-  switch (Conv) {
+OperandOwnershipKindMap OperandOwnershipKindClassifier::visitCallee(
+    CanSILFunctionType substCalleeType) {
+  ParameterConvention conv = substCalleeType->getCalleeConvention();
+  switch (conv) {
   case ParameterConvention::Indirect_In:
   case ParameterConvention::Indirect_In_Constant:
-    assert(!SILModuleConventions(Mod).isSILIndirect(
-        SILParameterInfo(SubstCalleeType, Conv)));
-    return {compatibleWithOwnership(ValueOwnershipKind::Owned),
-            UseLifetimeConstraint::MustBeInvalidated};
+    assert(!SILModuleConventions(mod).isSILIndirect(
+        SILParameterInfo(substCalleeType, conv)));
+    return Map::compatibilityMap(ValueOwnershipKind::Owned,
+                                 UseLifetimeConstraint::MustBeInvalidated);
   case ParameterConvention::Indirect_In_Guaranteed:
-    assert(!SILModuleConventions(Mod).isSILIndirect(
-        SILParameterInfo(SubstCalleeType, Conv)));
-    return {compatibleWithOwnership(ValueOwnershipKind::Owned),
-            UseLifetimeConstraint::MustBeLive};
+    assert(!SILModuleConventions(mod).isSILIndirect(
+        SILParameterInfo(substCalleeType, conv)));
+    return Map::compatibilityMap(ValueOwnershipKind::Guaranteed,
+                                 UseLifetimeConstraint::MustBeLive);
   case ParameterConvention::Indirect_Inout:
   case ParameterConvention::Indirect_InoutAliasable:
     llvm_unreachable("Illegal convention for callee");
   case ParameterConvention::Direct_Unowned:
-    if (isAddressOrTrivialType())
-      return {compatibleWithOwnership(ValueOwnershipKind::Trivial),
-              UseLifetimeConstraint::MustBeLive};
-    // We accept unowned, owned, and guaranteed in unowned positions.
-    return {true, UseLifetimeConstraint::MustBeLive};
+    return Map::allLive();
   case ParameterConvention::Direct_Owned:
-    return {compatibleWithOwnership(ValueOwnershipKind::Owned),
-            UseLifetimeConstraint::MustBeInvalidated};
+    return Map::compatibilityMap(ValueOwnershipKind::Owned,
+                                 UseLifetimeConstraint::MustBeInvalidated);
   case ParameterConvention::Direct_Guaranteed:
-    if (SubstCalleeType->isNoEscape())
-      return {compatibleWithOwnership(ValueOwnershipKind::Trivial),
-        UseLifetimeConstraint::MustBeLive};
-    return {compatibleWithOwnership(ValueOwnershipKind::Guaranteed),
-            UseLifetimeConstraint::MustBeLive};
+    if (substCalleeType->isNoEscape())
+      return Map::compatibilityMap(ValueOwnershipKind::Trivial,
+                                   UseLifetimeConstraint::MustBeLive);
+    return Map::compatibilityMap(ValueOwnershipKind::Guaranteed,
+                                 UseLifetimeConstraint::MustBeLive);
   }
 
   llvm_unreachable("Unhandled ParameterConvention in switch.");
@@ -889,117 +860,159 @@
 //
 // %val = enum $Optional<SomeClass>, #Optional.none // trivial ownership
 // apply %f(%val) : (@owned Optional<SomeClass>)    // owned argument
-OwnershipUseCheckerResult OwnershipCompatibilityUseChecker::visitEnumArgument(
-    EnumDecl *E, ValueOwnershipKind RequiredKind) {
-  // If this value is already categorized as a trivial ownership kind, it is
-  // safe to pass to any argument convention.
-  if (compatibleWithOwnership(ValueOwnershipKind::Trivial)) {
-    return {true, UseLifetimeConstraint::MustBeLive};
-  }
+OperandOwnershipKindMap OperandOwnershipKindClassifier::visitEnumArgument(
+    ValueOwnershipKind requiredKind) {
+  // If this value is already categorized as a trivial ownership kind,
+  // it is safe to pass to any argument convention. This is ok since
+  // we know that the enum type must match up as checked by the
+  // ownership verifier.
+  OperandOwnershipKindMap map;
+  map.addCompatibilityConstraint(ValueOwnershipKind::Trivial,
+                                 UseLifetimeConstraint::MustBeLive);
 
   // The operand has a non-trivial ownership kind. It must match the argument
   // convention.
-  auto ownership = getOwnershipKind();
-  UseLifetimeConstraint lifetimeConstraint;
-  if (ownership == ValueOwnershipKind::Owned) {
-    if (RequiredKind != ValueOwnershipKind::Owned) {
-      lifetimeConstraint = UseLifetimeConstraint::MustBeLive;
-    } else {
-      lifetimeConstraint = UseLifetimeConstraint::MustBeInvalidated;
-    }
+  if (requiredKind != ValueOwnershipKind::Owned) {
+    map.addCompatibilityConstraint(ValueOwnershipKind::Owned,
+                                   UseLifetimeConstraint::MustBeLive);
   } else {
-    lifetimeConstraint = UseLifetimeConstraint::MustBeLive;
+    map.addCompatibilityConstraint(ValueOwnershipKind::Owned,
+                                   UseLifetimeConstraint::MustBeInvalidated);
   }
-  return {ownership.isCompatibleWith(RequiredKind), lifetimeConstraint};
+  map.addCompatibilityConstraint(ValueOwnershipKind::Guaranteed,
+                                 UseLifetimeConstraint::MustBeLive);
+  map.addCompatibilityConstraint(ValueOwnershipKind::Unowned,
+                                 UseLifetimeConstraint::MustBeLive);
+  return map;
 }
 
 // We allow for trivial cases of enums with non-trivial cases to be passed in
 // non-trivial argument positions. This fits with modeling of a
 // SILFunctionArgument as a phi in a global program graph.
-OwnershipUseCheckerResult OwnershipCompatibilityUseChecker::visitApplyParameter(
+OperandOwnershipKindMap OperandOwnershipKindClassifier::visitApplyParameter(
     ValueOwnershipKind Kind, UseLifetimeConstraint Requirement) {
+
   // Check if we have an enum. If not, then we just check against the passed in
   // convention.
-  EnumDecl *E = getType().getEnumOrBoundGenericEnum();
-  if (!E) {
-    return {compatibleWithOwnership(Kind), Requirement};
+  if (!getType().getEnumOrBoundGenericEnum()) {
+    // We allow for owned to be passed to apply parameters.
+    if (Kind != ValueOwnershipKind::Owned) {
+      return Map::compatibilityMap(
+          {{Kind, Requirement},
+           {ValueOwnershipKind::Owned, UseLifetimeConstraint::MustBeLive}});
+    }
+    return Map::compatibilityMap(Kind, Requirement);
   }
-  return visitEnumArgument(E, Kind);
+
+  // Otherwise consider that we may have a payload with a trivial case
+  // that has other non-trivial cases.
+  return visitEnumArgument(Kind);
 }
 
 // Handle Apply and TryApply.
-OwnershipUseCheckerResult OwnershipCompatibilityUseChecker::
-visitFullApply(FullApplySite apply) {
-  // If we are visiting the callee, handle it specially.
-  if (getOperandIndex() == 0)
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitFullApply(FullApplySite apply) {
+  // If we are visiting the callee operand, handle it specially.
+  if (apply.isCalleeOperand(op)) {
     return visitCallee(apply.getSubstCalleeType());
+  }
 
   // Indirect return arguments are address types.
-  if (isAddressOrTrivialType())
-    return {compatibleWithOwnership(ValueOwnershipKind::Trivial),
-            UseLifetimeConstraint::MustBeLive};
+  if (apply.isIndirectResultOperand(op)) {
+    return Map::compatibilityMap(ValueOwnershipKind::Trivial,
+                                 UseLifetimeConstraint::MustBeLive);
+  }
 
-  unsigned argIndex = apply.getCalleeArgIndex(Op);
-  SILParameterInfo paramInfo =
-    apply.getSubstCalleeConv().getParamInfoForSILArg(argIndex);
+  unsigned argIndex = apply.getCalleeArgIndex(op);
+  auto conv = apply.getSubstCalleeConv();
+  SILParameterInfo paramInfo = conv.getParamInfoForSILArg(argIndex);
 
   switch (paramInfo.getConvention()) {
-  case ParameterConvention::Indirect_In:
   case ParameterConvention::Direct_Owned:
     return visitApplyParameter(ValueOwnershipKind::Owned,
                                UseLifetimeConstraint::MustBeInvalidated);
-  case ParameterConvention::Indirect_In_Constant:
   case ParameterConvention::Direct_Unowned:
-    // We accept unowned, owned, and guaranteed in unowned positions.
-    return {true, UseLifetimeConstraint::MustBeLive};
-  case ParameterConvention::Indirect_In_Guaranteed:
+    return Map::allLive();
+
+  case ParameterConvention::Indirect_In: {
+    // This expects an @trivial if we have lowered addresses and @
+    if (conv.useLoweredAddresses()) {
+      return visitApplyParameter(ValueOwnershipKind::Trivial,
+                                 UseLifetimeConstraint::MustBeLive);
+    }
+    // TODO: Once trivial is subsumed in any, this goes away.
+    auto map = visitApplyParameter(ValueOwnershipKind::Owned,
+                                   UseLifetimeConstraint::MustBeInvalidated);
+    map.addCompatibilityConstraint(ValueOwnershipKind::Trivial,
+                                   UseLifetimeConstraint::MustBeLive);
+    return map;
+  }
+
+  case ParameterConvention::Indirect_In_Guaranteed: {
+    // This expects an @trivial if we have lowered addresses and @
+    if (conv.useLoweredAddresses()) {
+      return visitApplyParameter(ValueOwnershipKind::Trivial,
+                                 UseLifetimeConstraint::MustBeLive);
+    }
+    // TODO: Once trivial is subsumed in any, this goes away.
+    auto map = visitApplyParameter(ValueOwnershipKind::Guaranteed,
+                                   UseLifetimeConstraint::MustBeLive);
+    map.addCompatibilityConstraint(ValueOwnershipKind::Trivial,
+                                   UseLifetimeConstraint::MustBeLive);
+    return map;
+  }
+
+  // The following conventions should take address types and thus be
+  // trivial.
+  case ParameterConvention::Indirect_In_Constant:
+  case ParameterConvention::Indirect_Inout:
+  case ParameterConvention::Indirect_InoutAliasable:
+    return visitApplyParameter(ValueOwnershipKind::Trivial,
+                               UseLifetimeConstraint::MustBeLive);
+
   case ParameterConvention::Direct_Guaranteed:
     // A +1 value may be passed to a guaranteed argument. From the caller's
     // point of view, this is just like a normal non-consuming use.
     // Direct_Guaranteed only accepts non-trivial types, but trivial types are
     // already handled above.
-    return visitApplyParameter(ValueOwnershipKind::Any,
+    return visitApplyParameter(ValueOwnershipKind::Guaranteed,
                                UseLifetimeConstraint::MustBeLive);
-  // The following conventions should take address types.
-  case ParameterConvention::Indirect_Inout:
-  case ParameterConvention::Indirect_InoutAliasable:
-    llvm_unreachable("Unexpected non-trivial parameter convention.");
   }
   llvm_unreachable("unhandled convension");
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitBeginApplyInst(BeginApplyInst *I) {
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitBeginApplyInst(BeginApplyInst *I) {
   return visitFullApply(I);
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitApplyInst(ApplyInst *I) {
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitApplyInst(ApplyInst *I) {
   return visitFullApply(I);
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitTryApplyInst(TryApplyInst *I) {
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitTryApplyInst(TryApplyInst *I) {
   return visitFullApply(I);
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitPartialApplyInst(PartialApplyInst *I) {
-  // All non-trivial types should be captured.
-  if (isAddressOrTrivialType()) {
-    return {compatibleWithOwnership(ValueOwnershipKind::Trivial),
-            UseLifetimeConstraint::MustBeLive};
-  }
-  return {compatibleWithOwnership(ValueOwnershipKind::Owned),
-          UseLifetimeConstraint::MustBeInvalidated};
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitPartialApplyInst(PartialApplyInst *I) {
+  return Map::compatibilityMap(
+      {{ValueOwnershipKind::Trivial, UseLifetimeConstraint::MustBeLive},
+       // All non-trivial types should be captured.
+       {ValueOwnershipKind::Owned, UseLifetimeConstraint::MustBeInvalidated}});
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitYieldInst(YieldInst *I) {
+// TODO: FIX THIS
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitYieldInst(YieldInst *I) {
   // Indirect return arguments are address types.
+  //
+  // TODO: Change this to check if this operand is an indirect result
   if (isAddressOrTrivialType())
-    return {compatibleWithOwnership(ValueOwnershipKind::Trivial),
-            UseLifetimeConstraint::MustBeLive};
+    return Map::compatibilityMap(ValueOwnershipKind::Trivial,
+                                 UseLifetimeConstraint::MustBeLive);
 
   auto fnType = I->getFunction()->getLoweredFunctionType();
   auto yieldInfo = fnType->getYields()[getOperandIndex()];
@@ -1011,7 +1024,7 @@
   case ParameterConvention::Indirect_In_Constant:
   case ParameterConvention::Direct_Unowned:
     // We accept unowned, owned, and guaranteed in unowned positions.
-    return {true, UseLifetimeConstraint::MustBeLive};
+    return Map::allLive();
   case ParameterConvention::Indirect_In_Guaranteed:
   case ParameterConvention::Direct_Guaranteed:
     return visitApplyParameter(ValueOwnershipKind::Guaranteed,
@@ -1024,50 +1037,45 @@
   llvm_unreachable("unhandled convension");
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitAssignInst(AssignInst *I) {
-  if (getValue() == I->getSrc()) {
-    if (isAddressOrTrivialType()) {
-      return {compatibleWithOwnership(ValueOwnershipKind::Trivial),
-              UseLifetimeConstraint::MustBeLive};
-    }
-    return {compatibleWithOwnership(ValueOwnershipKind::Owned),
-            UseLifetimeConstraint::MustBeInvalidated};
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitAssignInst(AssignInst *I) {
+  if (getValue() != I->getSrc()) {
+    return Map::compatibilityMap(ValueOwnershipKind::Trivial,
+                                 UseLifetimeConstraint::MustBeLive);
   }
 
-  return {true, UseLifetimeConstraint::MustBeLive};
+  return Map::compatibilityMap({
+      {ValueOwnershipKind::Trivial, UseLifetimeConstraint::MustBeLive},
+      {ValueOwnershipKind::Owned, UseLifetimeConstraint::MustBeInvalidated},
+  });
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitStoreInst(StoreInst *I) {
-  if (getValue() == I->getSrc()) {
-    if (isAddressOrTrivialType()) {
-      return {compatibleWithOwnership(ValueOwnershipKind::Trivial),
-              UseLifetimeConstraint::MustBeLive};
-    }
-    return {compatibleWithOwnership(ValueOwnershipKind::Owned),
-            UseLifetimeConstraint::MustBeInvalidated};
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitStoreInst(StoreInst *I) {
+  if (getValue() != I->getSrc()) {
+    return Map::compatibilityMap(ValueOwnershipKind::Trivial,
+                                 UseLifetimeConstraint::MustBeLive);
   }
-  return {true, UseLifetimeConstraint::MustBeLive};
+
+  return Map::compatibilityMap({
+      {ValueOwnershipKind::Trivial, UseLifetimeConstraint::MustBeLive},
+      {ValueOwnershipKind::Owned, UseLifetimeConstraint::MustBeInvalidated},
+  });
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitCopyBlockWithoutEscapingInst(
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitCopyBlockWithoutEscapingInst(
     CopyBlockWithoutEscapingInst *I) {
   // Consumes the closure parameter.
   if (getValue() == I->getClosure()) {
-    return {compatibleWithOwnership(ValueOwnershipKind::Owned),
-            UseLifetimeConstraint::MustBeInvalidated};
+    return Map::compatibilityMap(ValueOwnershipKind::Owned,
+                                 UseLifetimeConstraint::MustBeInvalidated);
   }
-  bool compatible = hasExactOwnership(ValueOwnershipKind::Any) ||
-                    !compatibleWithOwnership(ValueOwnershipKind::Trivial);
 
-  return { compatible, UseLifetimeConstraint::MustBeLive };
+  return Map::compatibleWithAllExcept(ValueOwnershipKind::Trivial);
 }
 
-
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitMarkDependenceInst(
+OperandOwnershipKindMap OperandOwnershipKindClassifier::visitMarkDependenceInst(
     MarkDependenceInst *MDI) {
 
   // Forward ownership if the mark_dependence instruction marks a dependence
@@ -1076,24 +1084,22 @@
     if (auto ResFnTy = MDI->getType().getAs<SILFunctionType>())
       if (auto BaseFnTy = MDI->getBase()->getType().getAs<SILFunctionType>())
         if (!ResFnTy->isNoEscape() && BaseFnTy->isNoEscape())
-          return {compatibleWithOwnership(ValueOwnershipKind::Owned),
-                  UseLifetimeConstraint::MustBeInvalidated};
+          return Map::compatibilityMap(
+              ValueOwnershipKind::Owned,
+              UseLifetimeConstraint::MustBeInvalidated);
 
   // We always treat mark dependence as a use that keeps a value alive. We will
   // be introducing a begin_dependence/end_dependence version of this later.
-  return {true, UseLifetimeConstraint::MustBeLive};
+  return Map::allLive();
 }
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitKeyPathInst(KeyPathInst *I) {
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitKeyPathInst(KeyPathInst *I) {
   // KeyPath moves the value in memory out of address operands, but the
   // ownership checker doesn't reason about that yet.
-  if (isAddressOrTrivialType()) {
-    return {compatibleWithOwnership(ValueOwnershipKind::Trivial),
-            UseLifetimeConstraint::MustBeLive};
-  }
-  return {compatibleWithOwnership(ValueOwnershipKind::Owned),
-          UseLifetimeConstraint::MustBeInvalidated};
+  return Map::compatibilityMap(
+      {{ValueOwnershipKind::Trivial, UseLifetimeConstraint::MustBeLive},
+       {ValueOwnershipKind::Owned, UseLifetimeConstraint::MustBeInvalidated}});
 }
 
 //===----------------------------------------------------------------------===//
@@ -1102,50 +1108,26 @@
 
 namespace {
 
-class OwnershipCompatibilityBuiltinUseChecker
-    : public SILBuiltinVisitor<OwnershipCompatibilityBuiltinUseChecker,
-                               OwnershipUseCheckerResult> {
+struct OperandOwnershipKindBuiltinClassifier
+    : SILBuiltinVisitor<OperandOwnershipKindBuiltinClassifier,
+                        OperandOwnershipKindMap> {
+  using Map = OperandOwnershipKindMap;
 
-  const OwnershipCompatibilityUseChecker &ParentChecker;
-
-public:
-  OwnershipCompatibilityBuiltinUseChecker(
-      OwnershipCompatibilityUseChecker &ParentChecker)
-      : ParentChecker(ParentChecker) {}
-
-  SILValue getValue() const { return ParentChecker.getValue(); }
-
-  ValueOwnershipKind getOwnershipKind() const {
-    return ParentChecker.getOwnershipKind();
-  }
-
-  unsigned getOperandIndex() const { return ParentChecker.getOperandIndex(); }
-
-  SILType getType() const { return ParentChecker.getType(); }
-
-  bool compatibleWithOwnership(ValueOwnershipKind Kind) const {
-    return ParentChecker.compatibleWithOwnership(Kind);
-  }
-
-  bool isAddressOrTrivialType() const {
-    return ParentChecker.isAddressOrTrivialType();
-  }
-
-  OwnershipUseCheckerResult visitLLVMIntrinsic(BuiltinInst *BI,
-                                               llvm::Intrinsic::ID ID) {
+  OperandOwnershipKindMap visitLLVMIntrinsic(BuiltinInst *BI,
+                                             llvm::Intrinsic::ID ID) {
     // LLVM intrinsics do not traffic in ownership, so if we have a result, it
     // must be trivial.
-    return {true, UseLifetimeConstraint::MustBeLive};
+    return {ValueOwnershipKind::Trivial, UseLifetimeConstraint::MustBeLive};
   }
 
     // BUILTIN_TYPE_CHECKER_OPERATION does not live past the type checker.
 #define BUILTIN_TYPE_CHECKER_OPERATION(ID, NAME)
 
 #define BUILTIN(ID, NAME, ATTRS)                                               \
-  OwnershipUseCheckerResult visit##ID(BuiltinInst *BI, StringRef Attr);
+  OperandOwnershipKindMap visit##ID(BuiltinInst *BI, StringRef Attr);
 #include "swift/AST/Builtins.def"
 
-  OwnershipUseCheckerResult check(BuiltinInst *BI) { return visit(BI); }
+  OperandOwnershipKindMap check(BuiltinInst *BI) { return visit(BI); }
 };
 
 } // end anonymous namespace
@@ -1154,11 +1136,11 @@
 // @guaranteed parameters. This means that we can only have a lifetime ending
 // use with our builtins if it is owned.
 #define CONSTANT_OWNERSHIP_BUILTIN(OWNERSHIP, USE_LIFETIME_CONSTRAINT, ID)     \
-  OwnershipUseCheckerResult                                                    \
-      OwnershipCompatibilityBuiltinUseChecker::visit##ID(BuiltinInst *BI,      \
-                                                         StringRef Attr) {     \
-    return {compatibleWithOwnership(ValueOwnershipKind::OWNERSHIP),            \
-            UseLifetimeConstraint::USE_LIFETIME_CONSTRAINT};                   \
+  OperandOwnershipKindMap OperandOwnershipKindBuiltinClassifier::visit##ID(    \
+      BuiltinInst *BI, StringRef Attr) {                                       \
+    return Map::compatibilityMap(                                              \
+        ValueOwnershipKind::OWNERSHIP,                                         \
+        UseLifetimeConstraint::USE_LIFETIME_CONSTRAINT);                       \
   }
 CONSTANT_OWNERSHIP_BUILTIN(Owned, MustBeLive, ErrorInMain)
 CONSTANT_OWNERSHIP_BUILTIN(Owned, MustBeLive, UnexpectedError)
@@ -1282,17 +1264,16 @@
 // Builtins that should be lowered to SIL instructions so we should never see
 // them.
 #define BUILTIN_SIL_OPERATION(ID, NAME, CATEGORY)                              \
-  OwnershipUseCheckerResult                                                    \
-      OwnershipCompatibilityBuiltinUseChecker::visit##ID(BuiltinInst *BI,      \
-                                                         StringRef Attr) {     \
+  OperandOwnershipKindMap OperandOwnershipKindBuiltinClassifier::visit##ID(    \
+      BuiltinInst *BI, StringRef Attr) {                                       \
     llvm_unreachable("Builtin should have been lowered to SIL instruction?!"); \
   }
 #define BUILTIN(X, Y, Z)
 #include "swift/AST/Builtins.def"
 
-OwnershipUseCheckerResult
-OwnershipCompatibilityUseChecker::visitBuiltinInst(BuiltinInst *BI) {
-  return OwnershipCompatibilityBuiltinUseChecker(*this).check(BI);
+OperandOwnershipKindMap
+OperandOwnershipKindClassifier::visitBuiltinInst(BuiltinInst *BI) {
+  return OperandOwnershipKindBuiltinClassifier().check(BI);
 }
 
 //===----------------------------------------------------------------------===//
@@ -1305,28 +1286,28 @@
 // refactored into a large state object that is used by functions.
 class SILValueOwnershipChecker {
   /// The result of performing the check.
-  llvm::Optional<bool> Result;
+  llvm::Optional<bool> result;
 
   /// The module that we are in.
-  SILModule &Mod;
+  SILModule &mod;
 
   /// A cache of dead-end basic blocks that we use to determine if we can
   /// ignore "leaks".
-  DeadEndBlocks &DEBlocks;
+  DeadEndBlocks &deadEndBlocks;
 
   /// The value whose ownership we will check.
-  SILValue Value;
+  SILValue value;
 
   /// The action that the checker should perform on detecting an error.
-  ErrorBehaviorKind ErrorBehavior;
+  ErrorBehaviorKind errorBehavior;
 
   /// The list of lifetime ending users that we found. Only valid if check is
   /// successful.
-  SmallVector<BranchPropagatedUser, 16> LifetimeEndingUsers;
+  SmallVector<BranchPropagatedUser, 16> lifetimeEndingUsers;
 
   /// The list of non lifetime ending users that we found. Only valid if check
   /// is successful.
-  SmallVector<BranchPropagatedUser, 16> RegularUsers;
+  SmallVector<BranchPropagatedUser, 16> regularUsers;
 
   /// The list of implicit non lifetime ending users that we found. This
   /// consists of instructions like end_borrow that end a scoped lifetime. We
@@ -1334,19 +1315,19 @@
   /// destroyed while that sub-scope is valid.
   ///
   /// TODO: Rename to SubBorrowScopeUsers?
-  SmallVector<BranchPropagatedUser, 4> ImplicitRegularUsers;
+  SmallVector<BranchPropagatedUser, 4> implicitRegularUsers;
 
   /// The set of blocks that we have visited.
-  SmallPtrSetImpl<SILBasicBlock *> &VisitedBlocks;
+  SmallPtrSetImpl<SILBasicBlock *> &visitedBlocks;
 
 public:
   SILValueOwnershipChecker(
-      SILModule &M, DeadEndBlocks &DEBlocks, SILValue V,
-      ErrorBehaviorKind ErrorBehavior,
-      llvm::SmallPtrSetImpl<SILBasicBlock *> &VisitedBlocks)
-      : Result(), Mod(M), DEBlocks(DEBlocks), Value(V),
-        ErrorBehavior(ErrorBehavior), VisitedBlocks(VisitedBlocks) {
-    assert(Value && "Can not initialize a checker with an empty SILValue");
+      SILModule &mod, DeadEndBlocks &deadEndBlocks, SILValue value,
+      ErrorBehaviorKind errorBehavior,
+      llvm::SmallPtrSetImpl<SILBasicBlock *> &visitedBlocks)
+      : result(), mod(mod), deadEndBlocks(deadEndBlocks), value(value),
+        errorBehavior(errorBehavior), visitedBlocks(visitedBlocks) {
+    assert(value && "Can not initialize a checker with an empty SILValue");
   }
 
   ~SILValueOwnershipChecker() = default;
@@ -1354,21 +1335,22 @@
   SILValueOwnershipChecker(SILValueOwnershipChecker &&) = delete;
 
   bool check() {
-    if (Result.hasValue())
-      return Result.getValue();
+    if (result.hasValue())
+      return result.getValue();
 
-    LLVM_DEBUG(llvm::dbgs() << "Verifying ownership of: " << *Value);
-    Result = checkUses();
-    if (!Result.getValue())
+    LLVM_DEBUG(llvm::dbgs() << "Verifying ownership of: " << *value);
+    result = checkUses();
+    if (!result.getValue())
       return false;
 
     SmallVector<BranchPropagatedUser, 32> allRegularUsers;
-    copy(RegularUsers, std::back_inserter(allRegularUsers));
-    copy(ImplicitRegularUsers, std::back_inserter(allRegularUsers));
-    Result = valueHasLinearLifetime(Value, LifetimeEndingUsers, allRegularUsers,
-                                    VisitedBlocks, DEBlocks, ErrorBehavior);
+    copy(regularUsers, std::back_inserter(allRegularUsers));
+    copy(implicitRegularUsers, std::back_inserter(allRegularUsers));
+    result =
+        valueHasLinearLifetime(value, lifetimeEndingUsers, allRegularUsers,
+                               visitedBlocks, deadEndBlocks, errorBehavior);
 
-    return Result.getValue();
+    return result.getValue();
   }
 
   using user_array_transform =
@@ -1378,134 +1360,175 @@
   /// A function that returns a range of lifetime ending users found for the
   /// given value.
   user_array getLifetimeEndingUsers() const {
-    assert(Result.hasValue() && "Can not call until check() is called");
-    assert(Result.getValue() && "Can not call if check() returned false");
+    assert(result.hasValue() && "Can not call until check() is called");
+    assert(result.getValue() && "Can not call if check() returned false");
 
-    user_array_transform Transform(
-        [](BranchPropagatedUser User) -> SILInstruction * {
-          return User.getInst();
+    user_array_transform transform(
+        [](BranchPropagatedUser user) -> SILInstruction * {
+          return user.getInst();
         });
-    return user_array(ArrayRef<BranchPropagatedUser>(LifetimeEndingUsers),
-                      Transform);
+    return user_array(ArrayRef<BranchPropagatedUser>(lifetimeEndingUsers),
+                      transform);
   }
 
   /// A function that returns a range of regular (i.e. "non lifetime ending")
   /// users found for the given value.
   user_array getRegularUsers() const {
-    assert(Result.hasValue() && "Can not call until check() is called");
-    assert(Result.getValue() && "Can not call if check() returned false");
+    assert(result.hasValue() && "Can not call until check() is called");
+    assert(result.getValue() && "Can not call if check() returned false");
 
-    user_array_transform Transform(
-        [](BranchPropagatedUser User) -> SILInstruction * {
-          return User.getInst();
+    user_array_transform transform(
+        [](BranchPropagatedUser user) -> SILInstruction * {
+          return user.getInst();
         });
-    return user_array(ArrayRef<BranchPropagatedUser>(RegularUsers), Transform);
+    return user_array(ArrayRef<BranchPropagatedUser>(regularUsers), transform);
   }
 
 private:
   bool checkUses();
-  void gatherUsers(SmallVectorImpl<BranchPropagatedUser> &LifetimeEndingUsers,
-                   SmallVectorImpl<BranchPropagatedUser> &RegularUsers,
-                   SmallVectorImpl<BranchPropagatedUser> &ImplicitRegularUsers);
+  bool gatherUsers(SmallVectorImpl<BranchPropagatedUser> &lifetimeEndingUsers,
+                   SmallVectorImpl<BranchPropagatedUser> &regularUsers,
+                   SmallVectorImpl<BranchPropagatedUser> &implicitRegularUsers);
 
   bool checkValueWithoutLifetimeEndingUses();
 
-  bool checkFunctionArgWithoutLifetimeEndingUses(SILFunctionArgument *Arg);
-  bool checkYieldWithoutLifetimeEndingUses(BeginApplyResult *Yield);
+  bool checkFunctionArgWithoutLifetimeEndingUses(SILFunctionArgument *arg);
+  bool checkYieldWithoutLifetimeEndingUses(BeginApplyResult *yield);
 
   bool isGuaranteedFunctionArgWithLifetimeEndingUses(
-      SILFunctionArgument *Arg,
-      const llvm::SmallVectorImpl<BranchPropagatedUser> &LifetimeEndingUsers)
-      const;
+      SILFunctionArgument *arg,
+      const SmallVectorImpl<BranchPropagatedUser> &lifetimeEndingUsers) const;
   bool isSubobjectProjectionWithLifetimeEndingUses(
-      SILValue Value,
-      const llvm::SmallVectorImpl<BranchPropagatedUser> &LifetimeEndingUsers)
-      const;
+      SILValue value,
+      const SmallVectorImpl<BranchPropagatedUser> &lifetimeEndingUsers) const;
 
   /// Depending on our initialization, either return false or call Func and
   /// throw an error.
-  bool handleError(llvm::function_ref<void()> &&MessagePrinterFunc) const {
-    if (ErrorBehavior.shouldPrintMessage()) {
-      MessagePrinterFunc();
+  bool handleError(function_ref<void()> &&messagePrinterFunc) const {
+    if (errorBehavior.shouldPrintMessage()) {
+      messagePrinterFunc();
     }
 
-    if (ErrorBehavior.shouldReturnFalse()) {
+    if (errorBehavior.shouldReturnFalse()) {
       return false;
     }
 
-    assert(ErrorBehavior.shouldAssert() && "At this point, we should assert");
+    assert(errorBehavior.shouldAssert() && "At this point, we should assert");
     llvm_unreachable("triggering standard assertion failure routine");
   }
 };
 
 } // end anonymous namespace
 
-void SILValueOwnershipChecker::gatherUsers(
-    SmallVectorImpl<BranchPropagatedUser> &LifetimeEndingUsers,
-    SmallVectorImpl<BranchPropagatedUser> &NonLifetimeEndingUsers,
-    SmallVectorImpl<BranchPropagatedUser> &ImplicitRegularUsers) {
+bool SILValueOwnershipChecker::gatherUsers(
+    SmallVectorImpl<BranchPropagatedUser> &lifetimeEndingUsers,
+    SmallVectorImpl<BranchPropagatedUser> &nonLifetimeEndingUsers,
+    SmallVectorImpl<BranchPropagatedUser> &implicitRegularUsers) {
 
   // See if Value is guaranteed. If we are guaranteed and not forwarding, then
   // we need to look through subobject uses for more uses. Otherwise, if we are
   // forwarding, we do not create any lifetime ending users/non lifetime ending
   // users since we verify against our base.
-  auto OwnershipKind = Value.getOwnershipKind();
-  bool IsGuaranteed = OwnershipKind == ValueOwnershipKind::Guaranteed;
-  bool IsOwned = OwnershipKind == ValueOwnershipKind::Owned;
+  auto ownershipKind = value.getOwnershipKind();
+  bool isGuaranteed = ownershipKind == ValueOwnershipKind::Guaranteed;
+  bool isOwned = ownershipKind == ValueOwnershipKind::Owned;
 
-  if (IsGuaranteed && isGuaranteedForwardingValue(Value))
-    return;
+  if (isGuaranteed && isGuaranteedForwardingValue(value))
+    return true;
 
   // Then gather up our initial list of users.
-  SmallVector<Operand *, 8> Users;
-  std::copy(Value->use_begin(), Value->use_end(), std::back_inserter(Users));
+  SmallVector<Operand *, 8> users;
+  std::copy(value->use_begin(), value->use_end(), std::back_inserter(users));
 
-  auto addCondBranchToList = [](SmallVectorImpl<BranchPropagatedUser> &List,
-                                CondBranchInst *CBI, unsigned OperandIndex) {
-    if (CBI->isConditionOperandIndex(OperandIndex)) {
-      List.emplace_back(CBI);
+  auto addCondBranchToList = [](SmallVectorImpl<BranchPropagatedUser> &list,
+                                CondBranchInst *cbi, unsigned operandIndex) {
+    if (cbi->isConditionOperandIndex(operandIndex)) {
+      list.emplace_back(cbi);
       return;
     }
 
-    bool isTrueOperand = CBI->isTrueOperandIndex(OperandIndex);
-    List.emplace_back(CBI, isTrueOperand ? CondBranchInst::TrueIdx
+    bool isTrueOperand = cbi->isTrueOperandIndex(operandIndex);
+    list.emplace_back(cbi, isTrueOperand ? CondBranchInst::TrueIdx
                                          : CondBranchInst::FalseIdx);
   };
 
-  while (!Users.empty()) {
-    Operand *Op = Users.pop_back_val();
-    SILInstruction *User = Op->getUser();
+  bool foundError = false;
+  while (!users.empty()) {
+    Operand *op = users.pop_back_val();
+    SILInstruction *user = op->getUser();
 
     // If this op is a type dependent operand, skip it. It is not interesting
     // from an ownership perspective.
-    if (User->isTypeDependentOperand(*Op))
+    if (user->isTypeDependentOperand(*op))
       continue;
 
-    if (OwnershipCompatibilityUseChecker(Mod, *Op, Value, ErrorBehavior)
-            .check(User)) {
-      LLVM_DEBUG(llvm::dbgs() << "        Lifetime Ending User: " << *User);
-      if (auto *CBI = dyn_cast<CondBranchInst>(User)) {
-        addCondBranchToList(LifetimeEndingUsers, CBI, Op->getOperandNumber());
+    bool isGuaranteedSubValue = false;
+    if (isGuaranteed && isGuaranteedForwardingInst(op->getUser())) {
+      isGuaranteedSubValue = true;
+    }
+
+    auto opOwnershipKindMap = op->getOwnershipKindMap(isGuaranteedSubValue);
+    // If our ownership kind doesn't match, track that we found an error, emit
+    // an error message optionally and then continue.
+    if (!opOwnershipKindMap.canAcceptKind(ownershipKind)) {
+      foundError = true;
+
+      // If we did not support /any/ ownership kind, it means that we found a
+      // conflicting answer so the kind map that was returned is the empty
+      // map. Put out a more specific error here.
+      if (!opOwnershipKindMap.data.any()) {
+        handleError([&]() {
+          llvm::errs() << "Function: '" << user->getFunction()->getName()
+                       << "'\n"
+                       << "Ill-formed SIL! Unable to compute ownership kind "
+                          "map for user?!\n"
+                       << "For terminator users, check that successors have "
+                          "compatible ownership kinds.\n"
+                       << "Value: " << op->get() << "User: " << *user
+                       << "Operand Number: " << op->getOperandNumber() << '\n'
+                       << "Conv: " << ownershipKind << "\n\n";
+        });
+        continue;
+      }
+
+      handleError([&]() {
+        llvm::errs() << "Function: '" << user->getFunction()->getName() << "'\n"
+                     << "Have operand with incompatible ownership?!\n"
+                     << "Value: " << op->get() << "User: " << *user
+                     << "Operand Number: " << op->getOperandNumber() << '\n'
+                     << "Conv: " << ownershipKind << '\n'
+                     << "OwnershipMap:\n"
+                     << opOwnershipKindMap << '\n';
+      });
+      continue;
+    }
+
+    auto lifetimeConstraint =
+        opOwnershipKindMap.getLifetimeConstraint(ownershipKind);
+    if (lifetimeConstraint == UseLifetimeConstraint::MustBeInvalidated) {
+      LLVM_DEBUG(llvm::dbgs() << "        Lifetime Ending User: " << *user);
+      if (auto *cbi = dyn_cast<CondBranchInst>(user)) {
+        addCondBranchToList(lifetimeEndingUsers, cbi, op->getOperandNumber());
       } else {
-        LifetimeEndingUsers.emplace_back(User);
+        lifetimeEndingUsers.emplace_back(user);
       }
     } else {
-      LLVM_DEBUG(llvm::dbgs() << "        Regular User: " << *User);
-      if (auto *CBI = dyn_cast<CondBranchInst>(User)) {
-        addCondBranchToList(NonLifetimeEndingUsers, CBI,
-                            Op->getOperandNumber());
+      LLVM_DEBUG(llvm::dbgs() << "        Regular User: " << *user);
+      if (auto *cbi = dyn_cast<CondBranchInst>(user)) {
+        addCondBranchToList(nonLifetimeEndingUsers, cbi,
+                            op->getOperandNumber());
       } else {
-        NonLifetimeEndingUsers.emplace_back(User);
+        nonLifetimeEndingUsers.emplace_back(user);
       }
     }
 
     // If our base value is not guaranteed, we do not to try to visit
     // subobjects.
-    if (!IsGuaranteed) {
+    if (!isGuaranteed) {
       // But if we are owned, check if we have any end_borrows. We
       // need to treat these as sub-scope users. We can rely on the
       // end_borrow to prevent recursion.
-      if (IsOwned) {
+      if (isOwned) {
         // Do a check if any of our users are begin_borrows. If we find such a
         // use, then we want to include the end_borrow associated with the
         // begin_borrow in our NonLifetimeEndingUser lists.
@@ -1514,11 +1537,11 @@
         // append to NonLifetimeEndingUsers without needing to deal with
         // iterator invalidation.
         SmallVector<SILInstruction *, 4> endBorrowInsts;
-        for (unsigned i : indices(NonLifetimeEndingUsers)) {
+        for (unsigned i : indices(nonLifetimeEndingUsers)) {
           if (auto *bbi = dyn_cast<BeginBorrowInst>(
-                  NonLifetimeEndingUsers[i].getInst())) {
+                  nonLifetimeEndingUsers[i].getInst())) {
             copy(bbi->getEndBorrows(),
-                 std::back_inserter(ImplicitRegularUsers));
+                 std::back_inserter(implicitRegularUsers));
           }
         }
       }
@@ -1527,7 +1550,7 @@
 
     // If we are guaranteed, but are not a guaranteed forwarding inst,
     // just continue. This user is just treated as a normal use.
-    if (!isGuaranteedForwardingInst(User))
+    if (!isGuaranteedForwardingInst(user))
       continue;
 
     // At this point, we know that we must have a forwarded subobject. Since the
@@ -1535,8 +1558,8 @@
     // or trivial. We now split into two cases, if the user is a terminator or
     // not. If we do not have a terminator, then just add the uses of all of
     // User's results to the worklist.
-    if (User->getResults().size()) {
-      for (SILValue result : User->getResults()) {
+    if (user->getResults().size()) {
+      for (SILValue result : user->getResults()) {
         if (result.getOwnershipKind() == ValueOwnershipKind::Trivial) {
           continue;
         }
@@ -1547,27 +1570,27 @@
         assert(result.getOwnershipKind() == ValueOwnershipKind::Guaranteed &&
                "Our value is guaranteed and this is a forwarding instruction. "
                "Should have guaranteed ownership as well.");
-        copy(result->getUses(), std::back_inserter(Users));
+        copy(result->getUses(), std::back_inserter(users));
       }
 
       continue;
     }
 
-    assert(User->getResults().empty());
+    assert(user->getResults().empty());
 
-    auto *TI = dyn_cast<TermInst>(User);
-    if (!TI) {
+    auto *ti = dyn_cast<TermInst>(user);
+    if (!ti) {
       continue;
     }
 
     // Otherwise if we have a terminator, add any as uses any end_borrow to
     // ensure that the subscope is completely enclsed within the super scope. We
     // require all of our arguments to be either trivial or guaranteed.
-    for (auto &Succ : TI->getSuccessors()) {
-      auto *BB = Succ.getBB();
+    for (auto &succ : ti->getSuccessors()) {
+      auto *succBlock = succ.getBB();
 
       // If we do not have any arguments, then continue.
-      if (BB->args_empty())
+      if (succBlock->args_empty())
         continue;
 
       // Otherwise, make sure that all arguments are trivial or guaranteed. If
@@ -1575,21 +1598,21 @@
       //
       // TODO: We could ignore this error and emit a more specific error on the
       // actual terminator.
-      for (auto *BBArg : BB->getPhiArguments()) {
+      for (auto *succArg : succBlock->getPhiArguments()) {
         // *NOTE* We do not emit an error here since we want to allow for more
         // specific errors to be found during use_verification.
         //
         // TODO: Add a flag that associates the terminator instruction with
         // needing to be verified. If it isn't verified appropriately, assert
         // when the verifier is destroyed.
-        auto BBArgOwnershipKind = BBArg->getOwnershipKind();
-        if (!BBArgOwnershipKind.isTrivialOrCompatibleWith(OwnershipKind)) {
+        auto succArgOwnershipKind = succArg->getOwnershipKind();
+        if (!succArgOwnershipKind.isTrivialOrCompatibleWith(ownershipKind)) {
           // This is where the error would go.
           continue;
         }
 
         // If we have a trivial value, just continue.
-        if (BBArgOwnershipKind == ValueOwnershipKind::Trivial)
+        if (succArgOwnershipKind == ValueOwnershipKind::Trivial)
           continue;
 
         // Otherwise add all end_borrow users for this BBArg to the
@@ -1597,19 +1620,25 @@
         // completely joint post-dominated by these users, so we use
         // them to ensure that all of BBArg's uses are completely
         // enclosed within the end_borrow of this argument.
-        for (auto *op : BBArg->getUses()) {
+        for (auto *op : succArg->getUses()) {
           if (auto *ebi = dyn_cast<EndBorrowInst>(op->getUser())) {
-            ImplicitRegularUsers.push_back(ebi);
+            implicitRegularUsers.push_back(ebi);
           }
         }
       }
     }
   }
+
+  // Return true if we did not have an error and false if we did find an error.
+  //
+  // The reason why we use this extra variable is to make sure that when we are
+  // testing, we print out all mismatching pairs rather than just the first.
+  return !foundError;
 }
 
 bool SILValueOwnershipChecker::checkFunctionArgWithoutLifetimeEndingUses(
-    SILFunctionArgument *Arg) {
-  switch (Arg->getOwnershipKind()) {
+    SILFunctionArgument *arg) {
+  switch (arg->getOwnershipKind()) {
   case ValueOwnershipKind::Guaranteed:
   case ValueOwnershipKind::Unowned:
   case ValueOwnershipKind::Trivial:
@@ -1621,19 +1650,19 @@
     break;
   }
 
-  if (DEBlocks.isDeadEnd(Arg->getParent()))
+  if (deadEndBlocks.isDeadEnd(arg->getParent()))
     return true;
 
   return !handleError([&] {
-    llvm::errs() << "Function: '" << Arg->getFunction()->getName() << "'\n"
+    llvm::errs() << "Function: '" << arg->getFunction()->getName() << "'\n"
                  << "    Owned function parameter without life ending uses!\n"
-                 << "Value: " << *Arg << '\n';
+                 << "Value: " << *arg << '\n';
   });
 }
 
 bool SILValueOwnershipChecker::checkYieldWithoutLifetimeEndingUses(
-    BeginApplyResult *Yield) {
-  switch (Yield->getOwnershipKind()) {
+    BeginApplyResult *yield) {
+  switch (yield->getOwnershipKind()) {
   case ValueOwnershipKind::Guaranteed:
   case ValueOwnershipKind::Unowned:
   case ValueOwnershipKind::Trivial:
@@ -1644,25 +1673,25 @@
     break;
   }
 
-  if (DEBlocks.isDeadEnd(Yield->getParent()->getParent()))
+  if (deadEndBlocks.isDeadEnd(yield->getParent()->getParent()))
     return true;
 
   return !handleError([&] {
-    llvm::errs() << "Function: '" << Yield->getFunction()->getName() << "'\n"
+    llvm::errs() << "Function: '" << yield->getFunction()->getName() << "'\n"
                  << "    Owned yield without life ending uses!\n"
-                 << "Value: " << *Yield << '\n';
+                 << "Value: " << *yield << '\n';
   });
 }
 bool SILValueOwnershipChecker::checkValueWithoutLifetimeEndingUses() {
   LLVM_DEBUG(llvm::dbgs() << "    No lifetime ending users?! Bailing early.\n");
-  if (auto *Arg = dyn_cast<SILFunctionArgument>(Value)) {
-    if (checkFunctionArgWithoutLifetimeEndingUses(Arg)) {
+  if (auto *arg = dyn_cast<SILFunctionArgument>(value)) {
+    if (checkFunctionArgWithoutLifetimeEndingUses(arg)) {
       return true;
     }
   }
 
-  if (auto *Yield = dyn_cast<BeginApplyResult>(Value)) {
-    if (checkYieldWithoutLifetimeEndingUses(Yield)) {
+  if (auto *yield = dyn_cast<BeginApplyResult>(value)) {
+    if (checkYieldWithoutLifetimeEndingUses(yield)) {
       return true;
     }
   }
@@ -1670,29 +1699,29 @@
   // Check if we are a guaranteed subobject. In such a case, we should never
   // have lifetime ending uses, since our lifetime is guaranteed by our
   // operand, so there is nothing further to do. So just return true.
-  if (isGuaranteedForwardingValue(Value) &&
-      Value.getOwnershipKind() == ValueOwnershipKind::Guaranteed)
+  if (isGuaranteedForwardingValue(value) &&
+      value.getOwnershipKind() == ValueOwnershipKind::Guaranteed)
     return true;
 
   // If we have an unowned value, then again there is nothing left to do.
-  if (Value.getOwnershipKind() == ValueOwnershipKind::Unowned)
+  if (value.getOwnershipKind() == ValueOwnershipKind::Unowned)
     return true;
 
-  if (auto *ParentBlock = Value->getParentBlock()) {
-    if (DEBlocks.isDeadEnd(ParentBlock)) {
+  if (auto *parentBlock = value->getParentBlock()) {
+    if (deadEndBlocks.isDeadEnd(parentBlock)) {
       LLVM_DEBUG(llvm::dbgs() << "    Ignoring transitively unreachable value "
                               << "without users!\n"
                               << "    Function: '"
-                              << Value->getFunction()->getName() << "'\n"
-                              << "    Value: " << *Value << '\n');
+                              << value->getFunction()->getName() << "'\n"
+                              << "    Value: " << *value << '\n');
       return true;
     }
   }
 
-  if (!isValueAddressOrTrivial(Value, Mod)) {
+  if (!isValueAddressOrTrivial(value, mod)) {
     return !handleError([&] {
-      llvm::errs() << "Function: '" << Value->getFunction()->getName() << "'\n";
-      if (Value.getOwnershipKind() == ValueOwnershipKind::Owned) {
+      llvm::errs() << "Function: '" << value->getFunction()->getName() << "'\n";
+      if (value.getOwnershipKind() == ValueOwnershipKind::Owned) {
         llvm::errs() << "Error! Found a leaked owned value that was never "
                         "consumed.\n";
       } else {
@@ -1700,7 +1729,7 @@
                         "guaranteed function args must have at least one "
                         "lifetime ending use?!\n";
       }
-      llvm::errs() << "Value: " << *Value << '\n';
+      llvm::errs() << "Value: " << *value << '\n';
     });
   }
 
@@ -1708,34 +1737,34 @@
 }
 
 bool SILValueOwnershipChecker::isGuaranteedFunctionArgWithLifetimeEndingUses(
-    SILFunctionArgument *Arg,
-    const llvm::SmallVectorImpl<BranchPropagatedUser> &LifetimeEndingUsers)
+    SILFunctionArgument *arg,
+    const llvm::SmallVectorImpl<BranchPropagatedUser> &lifetimeEndingUsers)
     const {
-  if (Arg->getOwnershipKind() != ValueOwnershipKind::Guaranteed)
+  if (arg->getOwnershipKind() != ValueOwnershipKind::Guaranteed)
     return true;
 
   return handleError([&] {
-    llvm::errs() << "    Function: '" << Arg->getFunction()->getName() << "'\n"
+    llvm::errs() << "    Function: '" << arg->getFunction()->getName() << "'\n"
                  << "    Guaranteed function parameter with life ending uses!\n"
-                 << "    Value: " << *Arg;
-    for (const auto &U : LifetimeEndingUsers) {
-      llvm::errs() << "    Lifetime Ending User: " << *U;
+                 << "    Value: " << *arg;
+    for (const auto &user : lifetimeEndingUsers) {
+      llvm::errs() << "    Lifetime Ending User: " << *user;
     }
     llvm::errs() << '\n';
   });
 }
 
 bool SILValueOwnershipChecker::isSubobjectProjectionWithLifetimeEndingUses(
-    SILValue Value,
-    const llvm::SmallVectorImpl<BranchPropagatedUser> &LifetimeEndingUsers)
+    SILValue value,
+    const llvm::SmallVectorImpl<BranchPropagatedUser> &lifetimeEndingUsers)
     const {
   return handleError([&] {
-    llvm::errs() << "    Function: '" << Value->getFunction()->getName()
+    llvm::errs() << "    Function: '" << value->getFunction()->getName()
                  << "'\n"
                  << "    Subobject projection with life ending uses!\n"
-                 << "    Value: " << *Value;
-    for (const auto &U : LifetimeEndingUsers) {
-      llvm::errs() << "    Lifetime Ending User: " << *U;
+                 << "    Value: " << *value;
+    for (const auto &user : lifetimeEndingUsers) {
+      llvm::errs() << "    Lifetime Ending User: " << *user;
     }
     llvm::errs() << '\n';
   });
@@ -1749,7 +1778,15 @@
   // 1. Verify that none of the uses are in the same block. This would be an
   // overconsume so in this case we assert.
   // 2. Verify that the uses are compatible with our ownership convention.
-  gatherUsers(LifetimeEndingUsers, RegularUsers, ImplicitRegularUsers);
+  if (!gatherUsers(lifetimeEndingUsers, regularUsers, implicitRegularUsers)) {
+    // Silently return false if this fails.
+    //
+    // If the user pass in a ErrorBehaviorKind that will assert, we
+    // will have asserted in gatherUsers(). If we get here the user
+    // asked us to optionally print out a message and indicate that
+    // the verification failed.
+    return false;
+  }
 
   // We can only have no lifetime ending uses if we have:
   //
@@ -1764,7 +1801,7 @@
   // more. Specifically, we should have /no/ lifetime ending uses of a
   // guaranteed function argument, since a guaranteed function argument should
   // outlive the current function always.
-  if (LifetimeEndingUsers.empty() && checkValueWithoutLifetimeEndingUses()) {
+  if (lifetimeEndingUsers.empty() && checkValueWithoutLifetimeEndingUses()) {
     return false;
   }
 
@@ -1773,9 +1810,9 @@
 
   // See if we have a guaranteed function address. Guaranteed function addresses
   // should never have any lifetime ending uses.
-  if (auto *Arg = dyn_cast<SILFunctionArgument>(Value)) {
-    if (!isGuaranteedFunctionArgWithLifetimeEndingUses(Arg,
-                                                       LifetimeEndingUsers)) {
+  if (auto *arg = dyn_cast<SILFunctionArgument>(value)) {
+    if (!isGuaranteedFunctionArgWithLifetimeEndingUses(arg,
+                                                       lifetimeEndingUsers)) {
       return false;
     }
   }
@@ -1783,10 +1820,10 @@
   // Check if we are an instruction that forwards forwards guaranteed
   // ownership. In such a case, we are a subobject projection. We should not
   // have any lifetime ending uses.
-  if (isGuaranteedForwardingValue(Value) &&
-      Value.getOwnershipKind() == ValueOwnershipKind::Guaranteed) {
-    if (!isSubobjectProjectionWithLifetimeEndingUses(Value,
-                                                     LifetimeEndingUsers)) {
+  if (isGuaranteedForwardingValue(value) &&
+      value.getOwnershipKind() == ValueOwnershipKind::Guaranteed) {
+    if (!isSubobjectProjectionWithLifetimeEndingUses(value,
+                                                     lifetimeEndingUsers)) {
       return false;
     }
   }
@@ -1798,6 +1835,14 @@
 //                           Top Level Entrypoints
 //===----------------------------------------------------------------------===//
 
+OperandOwnershipKindMap
+Operand::getOwnershipKindMap(bool isForwardingSubValue) const {
+  OperandOwnershipKindClassifier classifier(getUser()->getModule(), *this,
+                                            ErrorBehaviorKind::ReturnFalse,
+                                            isForwardingSubValue);
+  return classifier.visit(const_cast<SILInstruction *>(getUser()));
+}
+
 void SILInstruction::verifyOperandOwnership() const {
 #ifndef NDEBUG
   if (DisableOwnershipVerification)
@@ -1827,26 +1872,47 @@
   if (isa<TermInst>(this))
     return;
 
-  ErrorBehaviorKind ErrorBehavior;
+  ErrorBehaviorKind errorBehavior;
   if (IsSILOwnershipVerifierTestingEnabled) {
-    ErrorBehavior = ErrorBehaviorKind::PrintMessageAndReturnFalse;
+    errorBehavior = ErrorBehaviorKind::PrintMessageAndReturnFalse;
   } else {
-    ErrorBehavior = ErrorBehaviorKind::PrintMessageAndAssert;
+    errorBehavior = ErrorBehaviorKind::PrintMessageAndAssert;
   }
-  auto *Self = const_cast<SILInstruction *>(this);
-  for (const Operand &Op : getAllOperands()) {
-    if (isTypeDependentOperand(Op))
+  for (const Operand &op : getAllOperands()) {
+    // Skip type dependence operands.
+    if (isTypeDependentOperand(op))
       continue;
+    SILValue opValue = op.get();
+
     // Skip any SILUndef that we see.
-    if (isa<SILUndef>(Op.get()))
+    if (isa<SILUndef>(opValue))
       continue;
-    OwnershipCompatibilityUseChecker(getModule(), Op, Op.get(), ErrorBehavior)
-        .check(Self);
+    auto operandOwnershipKindMap = op.getOwnershipKindMap();
+    auto valueOwnershipKind = opValue.getOwnershipKind();
+    if (operandOwnershipKindMap.canAcceptKind(valueOwnershipKind))
+      continue;
+
+    if (errorBehavior.shouldPrintMessage()) {
+      llvm::errs() << "Found an operand with a value that is not compatible "
+                      "with the operand's operand ownership kind map.\n";
+      llvm::errs() << "Value: " << opValue;
+      llvm::errs() << "Value Ownership Kind: " << valueOwnershipKind << "\n";
+      llvm::errs() << "Instruction: " << *this;
+      llvm::errs() << "Operand Ownership Kind Map: " << operandOwnershipKindMap;
+    }
+
+    if (errorBehavior.shouldReturnFalse())
+      continue;
+
+    assert(errorBehavior.shouldAssert() &&
+           "At this point, we are expected to assert");
+    llvm_unreachable("triggering standard assertion failure routine");
   }
 #endif
 }
 
-void SILValue::verifyOwnership(SILModule &Mod, DeadEndBlocks *DEBlocks) const {
+void SILValue::verifyOwnership(SILModule &mod,
+                               DeadEndBlocks *deadEndBlocks) const {
 #ifndef NDEBUG
   if (DisableOwnershipVerification)
     return;
@@ -1858,62 +1924,65 @@
 
   // Since we do not have SILUndef, we now know that getFunction() should return
   // a real function. Assert in case this assumption is no longer true.
-  SILFunction *F = (*this)->getFunction();
-  assert(F && "Instructions and arguments should have a function");
+  SILFunction *f = (*this)->getFunction();
+  assert(f && "Instructions and arguments should have a function");
 
   // If the given function has unqualified ownership or we have been asked by
   // the user not to verify this function, there is nothing to verify.
-  if (!F->hasQualifiedOwnership() || !F->shouldVerifyOwnership())
+  if (!f->hasQualifiedOwnership() || !f->shouldVerifyOwnership())
     return;
 
-  ErrorBehaviorKind ErrorBehavior;
+  ErrorBehaviorKind errorBehavior;
   if (IsSILOwnershipVerifierTestingEnabled) {
-    ErrorBehavior = ErrorBehaviorKind::PrintMessageAndReturnFalse;
+    errorBehavior = ErrorBehaviorKind::PrintMessageAndReturnFalse;
   } else {
-    ErrorBehavior = ErrorBehaviorKind::PrintMessageAndAssert;
+    errorBehavior = ErrorBehaviorKind::PrintMessageAndAssert;
   }
-  llvm::SmallPtrSet<SILBasicBlock *, 32> LiveBlocks;
-  if (DEBlocks) {
-    SILValueOwnershipChecker(Mod, *DEBlocks, *this, ErrorBehavior, LiveBlocks)
+
+  llvm::SmallPtrSet<SILBasicBlock *, 32> liveBlocks;
+  if (deadEndBlocks) {
+    SILValueOwnershipChecker(mod, *deadEndBlocks, *this, errorBehavior,
+                             liveBlocks)
         .check();
   } else {
-    DeadEndBlocks DEBlocks((*this)->getFunction());
-    SILValueOwnershipChecker(Mod, DEBlocks, *this, ErrorBehavior, LiveBlocks)
+    DeadEndBlocks deadEndBlocks(f);
+    SILValueOwnershipChecker(mod, deadEndBlocks, *this, errorBehavior,
+                             liveBlocks)
         .check();
   }
 #endif
 }
 
-bool OwnershipChecker::checkValue(SILValue Value) {
-  RegularUsers.clear();
-  LifetimeEndingUsers.clear();
-  LiveBlocks.clear();
+bool OwnershipChecker::checkValue(SILValue value) {
+  regularUsers.clear();
+  lifetimeEndingUsers.clear();
+  liveBlocks.clear();
 
   // If we are SILUndef, just bail. SILUndef can pair with anything. Any uses of
   // the SILUndef will make sure that the matching checks out.
-  if (isa<SILUndef>(Value))
+  if (isa<SILUndef>(value))
     return false;
 
   // Since we do not have SILUndef, we now know that getFunction() should return
   // a real function. Assert in case this assumption is no longer true.
-  SILFunction *F = Value->getFunction();
-  assert(F && "Instructions and arguments should have a function");
+  SILFunction *f = value->getFunction();
+  assert(f && "Instructions and arguments should have a function");
 
   // If the given function has unqualified ownership, there is nothing further
   // to verify.
-  if (!F->hasQualifiedOwnership())
+  if (!f->hasQualifiedOwnership())
     return false;
 
-  ErrorBehaviorKind ErrorBehavior(ErrorBehaviorKind::ReturnFalse);
-  SILValueOwnershipChecker Checker(Mod, DEBlocks, Value, ErrorBehavior,
-                                   LiveBlocks);
-  if (!Checker.check()) {
+  ErrorBehaviorKind errorBehavior(ErrorBehaviorKind::ReturnFalse);
+  SILValueOwnershipChecker checker(mod, deadEndBlocks, value, errorBehavior,
+                                   liveBlocks);
+  if (!checker.check()) {
     return false;
   }
 
   // TODO: Make this more efficient.
-  copy(Checker.getRegularUsers(), std::back_inserter(RegularUsers));
-  copy(Checker.getLifetimeEndingUsers(),
-       std::back_inserter(LifetimeEndingUsers));
+  copy(checker.getRegularUsers(), std::back_inserter(regularUsers));
+  copy(checker.getLifetimeEndingUsers(),
+       std::back_inserter(lifetimeEndingUsers));
   return true;
 }
diff --git a/lib/SIL/SILValue.cpp b/lib/SIL/SILValue.cpp
index 42de105..a704147 100644
--- a/lib/SIL/SILValue.cpp
+++ b/lib/SIL/SILValue.cpp
@@ -286,3 +286,43 @@
   }
 }
 #endif
+
+//===----------------------------------------------------------------------===//
+//                          OperandOwnershipKindMap
+//===----------------------------------------------------------------------===//
+
+void OperandOwnershipKindMap::print(llvm::raw_ostream &os) const {
+  os << "-- OperandOwnershipKindMap --\n";
+
+  unsigned index = 0;
+  unsigned end = unsigned(ValueOwnershipKind::LastValueOwnershipKind) + 1;
+  while (index != end) {
+    auto kind = ValueOwnershipKind(index);
+    if (canAcceptKind(kind)) {
+      os << kind << ": Yes. Liveness: " << getLifetimeConstraint(kind) << "\n";
+    } else {
+      os << kind << ":  No."
+         << "\n";
+    }
+    ++index;
+  }
+}
+
+void OperandOwnershipKindMap::dump() const { print(llvm::dbgs()); }
+
+//===----------------------------------------------------------------------===//
+//                           UseLifetimeConstraint
+//===----------------------------------------------------------------------===//
+
+llvm::raw_ostream &swift::operator<<(llvm::raw_ostream &os,
+                                     UseLifetimeConstraint constraint) {
+  switch (constraint) {
+  case UseLifetimeConstraint::MustBeLive:
+    os << "MustBeLive";
+    break;
+  case UseLifetimeConstraint::MustBeInvalidated:
+    os << "MustBeInvalidated";
+    break;
+  }
+  return os;
+}
diff --git a/lib/SIL/UseOwnershipRequirement.h b/lib/SIL/UseOwnershipRequirement.h
deleted file mode 100644
index 44eb244..0000000
--- a/lib/SIL/UseOwnershipRequirement.h
+++ /dev/null
@@ -1,54 +0,0 @@
-//===--- UseOwnershipRequirement.h ----------------------------------------===//
-//
-// This source file is part of the Swift.org open source project
-//
-// Copyright (c) 2014 - 2017 Apple Inc. and the Swift project authors
-// Licensed under Apache License v2.0 with Runtime Library Exception
-//
-// See https://swift.org/LICENSE.txt for license information
-// See https://swift.org/CONTRIBUTORS.txt for the list of Swift project authors
-//
-//===----------------------------------------------------------------------===//
-///
-/// \file
-///
-/// This file contains declarations that enable clients to compute the ownership
-/// requirements that a use puts on an SSA value. This is used in coordination
-/// with the OwnershipChecker in SILOwnershipVerifier.cpp and the SILValue
-/// ValueOwnershipKind visitor in ValueOwnershipKindClassifier.cpp to perform
-/// SIL level ownership verification.
-///
-//===----------------------------------------------------------------------===//
-
-#ifndef SWIFT_SIL_USEOWNERSHIPREQUIREMENT_H
-#define SWIFT_SIL_USEOWNERSHIPREQUIREMENT_H
-
-namespace swift {
-
-/// What constraint does the given use of an SSA value put on the lifetime of
-/// the given SSA value.
-///
-/// There are two possible constraints: MustBeLive and
-/// MustBeInvalidated. MustBeLive means that the SSA value must be able to be
-/// used in a valid way at the given use point. MustBeInvalidated means that any
-/// use of given SSA value after this instruction on any path through this
-/// instruction.
-enum class UseLifetimeConstraint {
-  /// This use requires the SSA value to be live after the given instruction's
-  /// execution.
-  MustBeLive,
-
-  /// This use invalidates the given SSA value.
-  ///
-  /// This means that the given SSA value can not have any uses that are
-  /// reachable from this instruction. When a value has owned semantics this
-  /// means the SSA value is destroyed at this point. When a value has
-  /// guaranteed (i.e. shared borrow) semantics this means that the program
-  /// has left the scope of the borrowed SSA value and said value can not be
-  /// used.
-  MustBeInvalidated,
-};
-
-} // end namespace swift
-
-#endif
diff --git a/lib/SILOptimizer/Mandatory/SemanticARCOpts.cpp b/lib/SILOptimizer/Mandatory/SemanticARCOpts.cpp
index fc697a2..77d86c8 100644
--- a/lib/SILOptimizer/Mandatory/SemanticARCOpts.cpp
+++ b/lib/SILOptimizer/Mandatory/SemanticARCOpts.cpp
@@ -66,7 +66,7 @@
     // 1. copy_value.
     // 2. begin_borrow.
     // 3. end_borrow.
-    if (!all_of(Checker.LifetimeEndingUsers, [](SILInstruction *I) -> bool {
+    if (!all_of(Checker.lifetimeEndingUsers, [](SILInstruction *I) -> bool {
           return isa<DestroyValueInst>(I);
         }))
       continue;
@@ -74,7 +74,7 @@
     // Extra copy values that we should visit recursively.
     llvm::SmallVector<CopyValueInst *, 8> NewCopyInsts;
     llvm::SmallVector<SILInstruction *, 8> NewBorrowInsts;
-    if (!all_of(Checker.RegularUsers, [&](SILInstruction *I) -> bool {
+    if (!all_of(Checker.regularUsers, [&](SILInstruction *I) -> bool {
           if (auto *CVI = dyn_cast<CopyValueInst>(I)) {
             NewCopyInsts.push_back(CVI);
             return true;
@@ -94,8 +94,8 @@
     CVI->eraseFromParent();
     ++NumEliminatedInsts;
 
-    while (!Checker.LifetimeEndingUsers.empty()) {
-      Checker.LifetimeEndingUsers.pop_back_val()->eraseFromParent();
+    while (!Checker.lifetimeEndingUsers.empty()) {
+      Checker.lifetimeEndingUsers.pop_back_val()->eraseFromParent();
       ++NumEliminatedInsts;
     }
 
@@ -158,6 +158,9 @@
   void run() override {
     bool MadeChange = false;
     SILFunction *F = getFunction();
+    if (!F->getModule().isStdlibModule()) {
+      return;
+    }
 
     DeadEndBlocks DEBlocks(F);
     OwnershipChecker Checker{{}, {}, {}, {}, F->getModule(), DEBlocks};
diff --git a/lib/SILOptimizer/Transforms/DeadStoreElimination.cpp b/lib/SILOptimizer/Transforms/DeadStoreElimination.cpp
index d16f479..1f4f631 100644
--- a/lib/SILOptimizer/Transforms/DeadStoreElimination.cpp
+++ b/lib/SILOptimizer/Transforms/DeadStoreElimination.cpp
@@ -251,7 +251,7 @@
   SmallBitVector BBDeallocateLocation;
 
   /// The dead stores in the current basic block.
-  llvm::DenseSet<SILInstruction *> DeadStores;
+  llvm::SmallVector<SILInstruction *, 2> DeadStores;
 
   /// Keeps track of what stores to generate after the data flow stabilizes.
   /// these stores come from partial dead stores.
@@ -946,7 +946,7 @@
   // instruction is dead.
   if (Dead) {
     LLVM_DEBUG(llvm::dbgs() << "Instruction Dead: " << *I << "\n");
-    S->DeadStores.insert(I);
+    S->DeadStores.push_back(I);
     ++NumDeadStores;
     return;
   }
@@ -954,14 +954,14 @@
   // Partial dead store - stores to some locations are dead, but not all. This
   // is a partially dead store. Also at this point we know what locations are
   // dead.
-  llvm::DenseSet<LSLocation> Alives;
+  LSLocationList Alives;
   if (V.any()) {
     // Take out locations that are dead.
     for (unsigned i = 0; i < V.size(); ++i) {
       if (V.test(i))
         continue;
       // This location is alive.
-      Alives.insert(Locs[i]);
+      Alives.push_back(Locs[i]);
     }
 
     // Try to create as few aggregated stores as possible out of the locations.
@@ -994,7 +994,7 @@
 
     // Lastly, mark the old store as dead.
     LLVM_DEBUG(llvm::dbgs() << "Instruction Partially Dead: " << *I << "\n");
-    S->DeadStores.insert(I);
+    S->DeadStores.push_back(I);
     ++NumPartialDeadStores;
   }
 }
diff --git a/lib/SILOptimizer/Transforms/RedundantLoadElimination.cpp b/lib/SILOptimizer/Transforms/RedundantLoadElimination.cpp
index 7b17dbc..aacc1d0 100644
--- a/lib/SILOptimizer/Transforms/RedundantLoadElimination.cpp
+++ b/lib/SILOptimizer/Transforms/RedundantLoadElimination.cpp
@@ -416,8 +416,6 @@
 
 namespace {
 
-using BBValueMap = llvm::DenseMap<SILBasicBlock *, SILValue>;
-
 /// This class stores global state that we use when computing redundant load and
 /// their replacement in each basic block.
 class RLEContext {
@@ -1248,7 +1246,7 @@
 
 SILValue RLEContext::computePredecessorLocationValue(SILBasicBlock *BB,
                                                      LSLocation &L) {
-  BBValueMap Values;
+  llvm::SmallVector<std::pair<SILBasicBlock *, SILValue>, 8> Values;
   llvm::DenseSet<SILBasicBlock *> HandledBBs;
   llvm::SmallVector<SILBasicBlock *, 8> WorkList;
 
@@ -1277,7 +1275,7 @@
     // locations, collect and reduce them into a single value in the current
     // basic block.
     if (Forwarder.isConcreteValues(*this, L)) {
-      Values[CurBB] = Forwarder.reduceValuesAtEndOfBlock(*this, L);
+      Values.push_back({CurBB, Forwarder.reduceValuesAtEndOfBlock(*this, L)});
       continue;
     }
 
@@ -1301,7 +1299,7 @@
 
     // Reduce the available values into a single SILValue we can use to forward
     SILInstruction *IPt = CurBB->getTerminator();
-    Values[CurBB] = LSValue::reduce(L, &BB->getModule(), LSValues, IPt);
+    Values.push_back({CurBB, LSValue::reduce(L, &BB->getModule(), LSValues, IPt)});
   }
 
   // Finally, collect all the values for the SILArgument, materialize it using
@@ -1317,7 +1315,7 @@
 bool RLEContext::collectLocationValues(SILBasicBlock *BB, LSLocation &L,
                                        LSLocationValueMap &Values,
                                        ValueTableMap &VM) {
-  LSLocationSet CSLocs;
+  LSLocationList CSLocs;
   LSLocationList Locs;
   LSLocation::expand(L, &BB->getModule(), Locs, TE);
 
@@ -1328,7 +1326,7 @@
     Values[X] = getValue(VM[getLocationBit(X)]);
     if (!Values[X].isCoveringValue())
       continue;
-    CSLocs.insert(X);
+    CSLocs.push_back(X);
   }
 
   // For locations which we do not have concrete values for in this basic
@@ -1563,7 +1561,7 @@
   processBasicBlocksForRLE(Optimistic);
 
   // Finally, perform the redundant load replacements.
-  llvm::DenseSet<SILInstruction *> InstsToDelete;
+  llvm::SmallVector<SILInstruction *, 16> InstsToDelete;
   bool SILChanged = false;
   for (auto &B : *Fn) {
     auto &State = BBToLocState[&B];
@@ -1587,7 +1585,7 @@
                               << "With " << Iter->second);
       SILChanged = true;
       Iter->first->replaceAllUsesWith(Iter->second);
-      InstsToDelete.insert(Iter->first);
+      InstsToDelete.push_back(Iter->first);
       ++NumForwardedLoads;
     }
   }
diff --git a/lib/SILOptimizer/UtilityPasses/LSLocationPrinter.cpp b/lib/SILOptimizer/UtilityPasses/LSLocationPrinter.cpp
index fd964f3..9c5ac3a 100644
--- a/lib/SILOptimizer/UtilityPasses/LSLocationPrinter.cpp
+++ b/lib/SILOptimizer/UtilityPasses/LSLocationPrinter.cpp
@@ -181,7 +181,7 @@
   void printMemReduction(SILFunction &Fn) {
     LSLocation L;
     LSLocationList Locs;
-    llvm::DenseSet<LSLocation> SLocs;
+    LSLocationList SLocs;
     unsigned Counter = 0;
     for (auto &BB : Fn) {
       for (auto &II : BB) {
@@ -212,7 +212,7 @@
         // Reduction should not care about the order of the memory locations in
         // the set.
         for (auto I = Locs.begin(); I != Locs.end(); ++I) {
-          SLocs.insert(*I);
+          SLocs.push_back(*I);
         }
 
         // This should get the original (unexpanded) location back.
diff --git a/lib/SILOptimizer/Utils/CFG.cpp b/lib/SILOptimizer/Utils/CFG.cpp
index 71e2588..b59b1de 100644
--- a/lib/SILOptimizer/Utils/CFG.cpp
+++ b/lib/SILOptimizer/Utils/CFG.cpp
@@ -757,7 +757,7 @@
       auto *BBNode = DT->getNode(BB);
       SmallVector<DominanceInfoNode *, 8> Children(SuccBBNode->begin(),
                                                    SuccBBNode->end());
-      for (auto *ChildNode : *SuccBBNode)
+      for (auto *ChildNode : Children)
         DT->changeImmediateDominator(ChildNode, BBNode);
 
       DT->eraseNode(SuccBB);
diff --git a/lib/SILOptimizer/Utils/LoadStoreOptUtils.cpp b/lib/SILOptimizer/Utils/LoadStoreOptUtils.cpp
index 4c26167..a16be4b 100644
--- a/lib/SILOptimizer/Utils/LoadStoreOptUtils.cpp
+++ b/lib/SILOptimizer/Utils/LoadStoreOptUtils.cpp
@@ -185,36 +185,62 @@
   }
 }
 
-bool
-LSLocation::reduce(LSLocation Base, SILModule *M, LSLocationSet &Locs) {
+/// Gets the sub-locations of \p Base in \p SubLocations.
+/// Returns false if this is not possible or too complex.
+static bool
+getSubLocations(LSLocationList &SubLocations, LSLocation Base, SILModule *M,
+             const LSLocationList &Locs) {
   // If this is a class reference type, we have reached end of the type tree.
   if (Base.getType(M).getClassOrBoundGenericClass())
-    return Locs.find(Base) != Locs.end();
+    return false;
 
-  // This a don't expand node.
-  if (!shouldExpand(*M, Base.getType(M))) {
-    return Locs.find(Base) != Locs.end();
+  // Don't expand if it would be too complex. As Locs is a list (and not a set)
+  // we want to avoid quadratic complexity in replaceInner().
+  // Usually Locs is small anyway, because we limit expansion to 6 members.
+  // But with deeply nested types we could run in a corner case where Locs is
+  // large.
+  if (!shouldExpand(*M, Base.getType(M)) || Locs.size() >= 8) {
+    return false;
   }
 
   // This is a leaf node.
-  LSLocationList NextLevel;
-  Base.getNextLevelLSLocations(NextLevel, M);
-  if (NextLevel.empty())
-    return Locs.find(Base) != Locs.end();
+  Base.getNextLevelLSLocations(SubLocations, M);
+  return !SubLocations.empty();
+}
 
-  // This is not a leaf node, try to find whether all its children are alive.
+/// Replaces \p SubLocations with \p Base in \p Locs if all sub-locations are
+/// alive, i.e. present in \p Locs.
+static bool
+replaceSubLocations(LSLocation Base, SILModule *M, LSLocationList &Locs,
+                    const LSLocationList &SubLocations) {
+  // Find whether all its children of Base are alive.
   bool Alive = true;
-  for (auto &X : NextLevel) {
-    Alive &= LSLocation::reduce(X, M, Locs);
+  for (auto &X : SubLocations) {
+    // Recurse into the next level.
+    LSLocationList NextInnerLevel;
+    if (getSubLocations(NextInnerLevel, X, M, Locs)) {
+      Alive &= replaceSubLocations(X, M, Locs, NextInnerLevel);
+    } else {
+      Alive &= is_contained(Locs, X);
+    }
   }
 
   // All next level locations are alive, create the new aggregated location.
-  if (Alive) {
-    for (auto &X : NextLevel)
-      Locs.erase(X);
-    Locs.insert(Base);
-  }
-  return Alive;
+  if (!Alive)
+    return false;
+
+  auto newEnd = std::remove_if(Locs.begin(), Locs.end(), [&](const LSLocation &L) {
+    return is_contained(SubLocations, L);
+  });
+  Locs.erase(newEnd, Locs.end());
+  Locs.push_back(Base);
+  return true;
+}
+
+void LSLocation::reduce(LSLocation Base, SILModule *M, LSLocationList &Locs) {
+  LSLocationList SubLocations;
+  if (getSubLocations(SubLocations, Base, M, Locs))
+    replaceSubLocations(Base, M, Locs, SubLocations);
 }
 
 void
diff --git a/lib/Sema/CSApply.cpp b/lib/Sema/CSApply.cpp
index 72531e5..587ebd7 100644
--- a/lib/Sema/CSApply.cpp
+++ b/lib/Sema/CSApply.cpp
@@ -3573,12 +3573,10 @@
 
       auto &tc = cs.getTypeChecker();
 
-      // Since this is literal initialization, we don't
-      // really need to keep wrapping coercion around.
+      // If this is a literal that got converted into constructor call
+      // lets put proper source information in place.
       if (expr->isLiteralInit()) {
         auto *literalInit = expr->getSubExpr();
-        // If literal got converted into constructor call
-        // lets put proper source information in place.
         if (auto *call = dyn_cast<CallExpr>(literalInit)) {
           call->getFn()->forEachChildExpr([&](Expr *subExpr) -> Expr * {
             auto *TE = dyn_cast<TypeExpr>(subExpr);
@@ -3600,7 +3598,10 @@
         }
 
         literalInit->setImplicit(false);
-        return literalInit;
+
+        // Keep the coercion around, because it contains the source range
+        // for the original constructor call.
+        return expr;
       }
 
       // Turn the subexpression into an rvalue.
diff --git a/stdlib/public/core/Builtin.swift b/stdlib/public/core/Builtin.swift
index 6119388..c007950 100644
--- a/stdlib/public/core/Builtin.swift
+++ b/stdlib/public/core/Builtin.swift
@@ -178,13 +178,13 @@
   Builtin.conditionallyUnreachable()
 }
 
-@inlinable // FIXME(sil-serialize-all)
+@usableFromInline
 @_silgen_name("_swift_isClassOrObjCExistentialType")
 internal func _swift_isClassOrObjCExistentialType<T>(_ x: T.Type) -> Bool
 
 /// Returns `true` iff `T` is a class type or an `@objc` existential such as
 /// `AnyObject`.
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 @inline(__always)
 internal func _isClassOrObjCExistential<T>(_ x: T.Type) -> Bool {
 
@@ -244,7 +244,7 @@
 
 import SwiftShims
 
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 @inline(__always)
 public func _getUnsafePointerToStoredProperties(_ x: AnyObject)
   -> UnsafeMutableRawPointer {
@@ -298,28 +298,28 @@
 // Declare it here instead of RuntimeShims.h, because we need to specify
 // the type of argument to be AnyClass. This is currently not possible
 // when using RuntimeShims.h
-@inlinable // FIXME(sil-serialize-all)
+@usableFromInline
 @_silgen_name("_objcClassUsesNativeSwiftReferenceCounting")
 internal func _usesNativeSwiftReferenceCounting(_ theClass: AnyClass) -> Bool
 #else
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 @inline(__always)
 internal func _usesNativeSwiftReferenceCounting(_ theClass: AnyClass) -> Bool {
   return true
 }
 #endif
 
-@inlinable // FIXME(sil-serialize-all)
+@usableFromInline
 @_silgen_name("_getSwiftClassInstanceExtents")
 internal func getSwiftClassInstanceExtents(_ theClass: AnyClass)
   -> (negative: UInt, positive: UInt)
 
-@inlinable // FIXME(sil-serialize-all)
+@usableFromInline
 @_silgen_name("_getObjCClassInstanceExtents")
 internal func getObjCClassInstanceExtents(_ theClass: AnyClass)
   -> (negative: UInt, positive: UInt)
 
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 @inline(__always)
 internal func _class_getInstancePositiveExtentSize(_ theClass: AnyClass) -> Int {
 #if _runtime(_ObjC)
@@ -330,8 +330,7 @@
 }
 
 @inlinable
-internal
-func _isValidAddress(_ address: UInt) -> Bool {
+internal func _isValidAddress(_ address: UInt) -> Bool {
   // TODO: define (and use) ABI max valid pointer value
   return address >= _swift_abi_LeastValidPointerValue
 }
@@ -340,17 +339,17 @@
 
 // TODO(<rdar://problem/34837023>): Get rid of superfluous UInt constructor
 // calls
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 internal var _objCTaggedPointerBits: UInt {
   @inline(__always) get { return UInt(_swift_BridgeObject_TaggedPointerBits) }
 }
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 internal var _objectPointerSpareBits: UInt {
     @inline(__always) get {
       return UInt(_swift_abi_SwiftSpareBitsMask) & ~_objCTaggedPointerBits
     }
 }
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 internal var _objectPointerLowSpareBitShift: UInt {
     @inline(__always) get {
       _sanityCheck(_swift_abi_ObjCReservedLowBits < 2,
@@ -361,37 +360,37 @@
 
 #if arch(i386) || arch(arm) || arch(powerpc64) || arch(powerpc64le) || arch(
   s390x)
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 internal var _objectPointerIsObjCBit: UInt {
     @inline(__always) get { return 0x0000_0002 }
 }
 #else
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 internal var _objectPointerIsObjCBit: UInt {
   @inline(__always) get { return 0x4000_0000_0000_0000 }
 }
 #endif
 
 /// Extract the raw bits of `x`.
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 @inline(__always)
 internal func _bitPattern(_ x: Builtin.BridgeObject) -> UInt {
   return UInt(Builtin.castBitPatternFromBridgeObject(x))
 }
 
 /// Extract the raw spare bits of `x`.
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 @inline(__always)
 internal func _nonPointerBits(_ x: Builtin.BridgeObject) -> UInt {
   return _bitPattern(x) & _objectPointerSpareBits
 }
 
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 @inline(__always)
 internal func _isObjCTaggedPointer(_ x: AnyObject) -> Bool {
   return (Builtin.reinterpretCast(x) & _objCTaggedPointerBits) != 0
 }
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 @inline(__always)
 internal func _isObjCTaggedPointer(_ x: UInt) -> Bool {
   return (x & _objCTaggedPointerBits) != 0
@@ -507,24 +506,25 @@
 // NativeObject
 //
 
-@inline(__always)
 @inlinable
+@inline(__always)
 public func _nativeObject(fromNative x: AnyObject) -> Builtin.NativeObject {
   _sanityCheck(!_isObjCTaggedPointer(x))
   let native = Builtin.unsafeCastToNativeObject(x)
   // _sanityCheck(native == Builtin.castToNativeObject(x))
   return native
 }
-@inline(__always)
+
 @inlinable
+@inline(__always)
 public func _nativeObject(
   fromBridge x: Builtin.BridgeObject
 ) -> Builtin.NativeObject {
   return _nativeObject(fromNative: _bridgeObject(toNative: x))
 }
 
-@inline(__always)
 @inlinable
+@inline(__always)
 public func _nativeObject(toNative x: Builtin.NativeObject) -> AnyObject {
   return Builtin.castFromNativeObject(x)
 }
@@ -547,7 +547,7 @@
 ///
 /// - Precondition: `bits & _objectPointerIsObjCBit == 0`,
 ///   `bits & _objectPointerSpareBits == bits`.
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 @inline(__always)
 internal func _makeNativeBridgeObject(
   _ nativeObject: AnyObject, _ bits: UInt
@@ -560,7 +560,7 @@
 }
 
 /// Create a `BridgeObject` around the given `objCObject`.
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 @inline(__always)
 public // @testable
 func _makeObjCBridgeObject(
@@ -580,7 +580,7 @@
 ///   2. if `object` is a tagged pointer, `bits == 0`.  Otherwise,
 ///      `object` is either a native object, or `bits ==
 ///      _objectPointerIsObjCBit`.
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 @inline(__always)
 internal func _makeBridgeObject(
   _ object: AnyObject, _ bits: UInt
@@ -609,14 +609,13 @@
 
 /// Returns the superclass of `t`, if any.  The result is `nil` if `t` is
 /// a root class or class protocol.
-public
-func _getSuperclass(_ t: AnyClass) -> AnyClass? {
+public func _getSuperclass(_ t: AnyClass) -> AnyClass? {
   return _swift_class_getSuperclass(t)
 }
 
 /// Returns the superclass of `t`, if any.  The result is `nil` if `t` is
 /// not a class, is a root class, or is a class protocol.
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 @inline(__always)
 public // @testable
 func _getSuperclass(_ t: Any.Type) -> AnyClass? {
@@ -688,7 +687,7 @@
 }
 
 /// Extract an object reference from an Any known to contain an object.
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 internal func _unsafeDowncastToAnyObject(fromAny any: Any) -> AnyObject {
   _sanityCheck(type(of: any) is AnyObject.Type
                || type(of: any) is AnyObject.Protocol,
@@ -712,7 +711,7 @@
 // definitions below after the stdlib's diagnostic passes run, so that the
 // `staticReport`s don't fire while building the standard library, but do
 // fire if they ever show up in code that uses the standard library.
-@inlinable // FIXME(sil-serialize-all)
+@inlinable
 @inline(__always)
 public // internal with availability
 func _trueAfterDiagnostics() -> Builtin.Int1 {
diff --git a/stdlib/public/core/FloatingPointTypes.swift.gyb b/stdlib/public/core/FloatingPointTypes.swift.gyb
index d79730a..80ecf2d 100644
--- a/stdlib/public/core/FloatingPointTypes.swift.gyb
+++ b/stdlib/public/core/FloatingPointTypes.swift.gyb
@@ -1595,13 +1595,13 @@
   // falling back on the generic _convert operation otherwise.
   @_transparent
   public init<Source : BinaryInteger>(_ value: Source) {
-    if value.bitWidth <= 64 {
+    if value.bitWidth <= ${word_bits} {
       if Source.isSigned {
-        let asI64 = Int64(truncatingIfNeeded: value)
-        _value = Builtin.sitofp_Int64_FPIEEE${bits}(asI64._value)
+        let asInt = Int(truncatingIfNeeded: value)
+        _value = Builtin.sitofp_Int${word_bits}_FPIEEE${bits}(asInt._value)
       } else {
-        let asU64 = Int64(truncatingIfNeeded: value)
-        _value = Builtin.uitofp_Int64_FPIEEE${bits}(asU64._value)
+        let asUInt = Int(truncatingIfNeeded: value)
+        _value = Builtin.uitofp_Int${word_bits}_FPIEEE${bits}(asUInt._value)
       }
     } else {
       self = ${Self}._convert(from: value).value
diff --git a/stdlib/public/core/IntegerTypes.swift.gyb b/stdlib/public/core/IntegerTypes.swift.gyb
index 30b284a..6e07d71 100644
--- a/stdlib/public/core/IntegerTypes.swift.gyb
+++ b/stdlib/public/core/IntegerTypes.swift.gyb
@@ -1617,7 +1617,7 @@
 % if BuiltinName == 'Int32':
     self._value = Builtin.truncOrBitCast_Word_Int32(_v)
 % elif BuiltinName == 'Int64':
-    self._value = Builtin.zextOrBitCast_Word_Int64(_v)
+    self._value = Builtin.${z}extOrBitCast_Word_Int64(_v)
 % end
   }
 
@@ -1625,7 +1625,7 @@
   public // @testable
   var _builtinWordValue: Builtin.Word {
 % if BuiltinName == 'Int32':
-    return Builtin.zextOrBitCast_Int32_Word(_value)
+    return Builtin.${z}extOrBitCast_Int32_Word(_value)
 % elif BuiltinName == 'Int64':
     return Builtin.truncOrBitCast_Int64_Word(_value)
 % end
diff --git a/stdlib/public/core/Reverse.swift b/stdlib/public/core/Reverse.swift
index 4c514bf..4460801 100644
--- a/stdlib/public/core/Reverse.swift
+++ b/stdlib/public/core/Reverse.swift
@@ -257,7 +257,7 @@
   /// - Complexity: O(1)
   @inlinable
   @available(swift, introduced: 4.2)
-  public func reversed() -> Base {
+  public __consuming func reversed() -> Base {
     return _base
   }
 }
@@ -289,7 +289,7 @@
   ///
   /// - Complexity: O(1)
   @inlinable
-  public func reversed() -> ReversedCollection<Self> {
+  public __consuming func reversed() -> ReversedCollection<Self> {
     return ReversedCollection(_base: self)
   }
 }
@@ -303,7 +303,7 @@
   ///
   /// - Complexity: O(1)
   @inlinable
-  public func reversed() -> LazyCollection<ReversedCollection<Elements>> {
+  public __consuming func reversed() -> LazyCollection<ReversedCollection<Elements>> {
     return ReversedCollection(_base: elements).lazy
   }
 }
diff --git a/stdlib/public/core/SequenceAlgorithms.swift b/stdlib/public/core/SequenceAlgorithms.swift
index c73daa2..49c5cfc 100644
--- a/stdlib/public/core/SequenceAlgorithms.swift
+++ b/stdlib/public/core/SequenceAlgorithms.swift
@@ -750,7 +750,7 @@
   ///
   /// - Complexity: O(*n*), where *n* is the length of the sequence.
   @inlinable
-  public func reversed() -> [Element] {
+  public __consuming func reversed() -> [Element] {
     // FIXME(performance): optimize to 1 pass?  But Array(self) can be
     // optimized to a memcpy() sometimes.  Those cases are usually collections,
     // though.
diff --git a/test/Constraints/diagnostics.swift b/test/Constraints/diagnostics.swift
index 9544230..b1bf0f4 100644
--- a/test/Constraints/diagnostics.swift
+++ b/test/Constraints/diagnostics.swift
@@ -953,7 +953,7 @@
     case bar
   }
 
-  // expected-error@+2 {{binary operator '*' cannot be applied to operands of type 'Int' and 'Float'}} {{35-35=Int(}} {{42-42=)}}
+  // expected-error@+2 {{binary operator '*' cannot be applied to operands of type 'Int' and 'Float'}} {{35-35=Int(}} {{43-43=)}}
   // expected-note@+1 {{expected an argument list of type '(Int, Int)'}}
   let _: Int = Foo.bar.rawValue * Float(0)
 
diff --git a/test/IRGen/abi_v7k.swift b/test/IRGen/abi_v7k.swift
index 41c37d0..34107aa 100644
--- a/test/IRGen/abi_v7k.swift
+++ b/test/IRGen/abi_v7k.swift
@@ -337,69 +337,3 @@
     var r = Ret(min:currentMin, max:currentMax, min2:currentMin, max2:currentMax, min3:currentMin, max3:currentMax)
     return r
 }
-
-// Passing struct: Int8, MyPoint x 10, MySize * 10
-// CHECK-LABEL: define hidden swiftcc double @"$s8test_v7k0A4Ret5{{.*}}"(%T8test_v7k7MyRect3V* noalias nocapture dereferenceable(328))
-// V7K-LABEL: _$s8test_v7k0A4Ret5
-// V7K:        ldrb    r1, [r0]
-// V7K:        strb.w  r1, [sp, #52]
-// V7K:        ldrsb.w r1, [sp, #52]
-// V7K:        vmov    s0, r1
-// V7K:   vcvt.f64.s32    d16, s0
-// V7K:  ldr     r1, [r0, #8]
-// V7K:  str     r1, [sp, #24]
-// V7K:  ldr     r1, [r0, #12]
-// V7K:  str     r1, [sp, #28]
-// V7K:  ldr     r1, [r0, #16]
-// V7K:  str     r1, [sp, #32]
-// V7K:  ldr     r1, [r0, #20]
-// V7K:  str     r1, [sp, #36]
-// V7K:  ldr     r1, [sp, #24]
-// V7K:  str     r1, [sp, #40]
-// V7K:  ldr     r1, [sp, #28]
-// V7K:  str     r1, [sp, #44]
-// V7K:  vldr    d18, [sp, #40]
-// V7K:  vadd.f64        d16, d16, d18
-// V7K:  ldr.w     r1, [r0, #296]
-// V7K:  str     r1, [sp]
-// V7K:  ldr.w     r1, [r0, #300]
-// V7K:  str     r1, [sp, #4]
-// V7K:  ldr.w     r1, [r0, #304]
-// V7K:  str     r1, [sp, #8]
-// V7K:  ldr.w     r0, [r0, #308]
-// V7K:  str     r0, [sp, #12]
-// V7K:  ldr     r0, [sp]
-// V7K:  str     r0, [sp, #16]
-// V7K:  ldr     r0, [sp, #4]
-// V7K:  str     r0, [sp, #20]
-// V7K:  vldr    d18, [sp, #16]
-// V7K:  vadd.f64        d0, d16, d18
-// V7K:  add     sp, #56
-// V7K:  bx      lr
-
-struct MyRect3 {
-  var t: Int8
-  var p: MyPoint
-  var p2: MyPoint
-  var s: MySize
-  var s2: MySize
-  var p3: MyPoint
-  var p4: MyPoint
-  var s3: MySize
-  var s4: MySize
-  var p5: MyPoint
-  var p6: MyPoint
-  var s5: MySize
-  var s6: MySize
-  var p7: MyPoint
-  var p8: MyPoint
-  var s7: MySize
-  var s8: MySize
-  var p9: MyPoint
-  var p10: MyPoint
-  var s9: MySize
-  var s10: MySize
-}
-func testRet5(r: MyRect3) -> Double {
-  return Double(r.t) + r.p.x + r.s9.w
-}
diff --git a/test/SIL/ownership-verifier/opaque_use_verifier.sil b/test/SIL/ownership-verifier/opaque_use_verifier.sil
index 7ab9101..273ec38 100644
--- a/test/SIL/ownership-verifier/opaque_use_verifier.sil
+++ b/test/SIL/ownership-verifier/opaque_use_verifier.sil
@@ -79,3 +79,13 @@
   %18 = tuple ()
   return %18 : $()
 }
+
+sil @passTrivialAsOpaqueValue : $@convention(thin) (Builtin.Int64) -> () {
+bb0(%0 : @trivial $Builtin.Int64):
+  %1 = function_ref @opaque_copy : $@convention(thin) <T> (@in_guaranteed T) -> @out T
+  %2 = apply %1<Builtin.Int64>(%0) : $@convention(thin) <T> (@in_guaranteed T) -> @out T
+  %3 = function_ref @opaque_arg_copy : $@convention(thin) <T> (@in T) -> @out T
+  apply %3<Builtin.Int64>(%0) : $@convention(thin) <T> (@in T) -> @out T
+  %9999 = tuple()
+  return %9999 : $()
+}
diff --git a/test/SIL/ownership-verifier/over_consume.sil b/test/SIL/ownership-verifier/over_consume.sil
index bb96892..f87f5fa 100644
--- a/test/SIL/ownership-verifier/over_consume.sil
+++ b/test/SIL/ownership-verifier/over_consume.sil
@@ -148,7 +148,6 @@
 // CHECK-LABEL: Function: 'ref_element_addr_requires_borrow'
 // CHECK: Have operand with incompatible ownership?!
 // CHECK: Value:   %0 = argument of bb0 : $RefWithInt
-// CHECK: BaseValue:    %0 = argument of bb0 : $RefWithInt
 // CHECK: User:   %1 = ref_element_addr %0 : $RefWithInt, #RefWithInt.value
 // CHECK: Conv: owned
 sil @ref_element_addr_requires_borrow : $@convention(thin) (@owned RefWithInt) -> () {
@@ -176,11 +175,17 @@
 }
 
 // CHECK-LABEL: Function: 'switch_enum_mismatching_argument_guaranteed_to_owned'
-// CHECK: Error! Argument ownership kind does not match terminator!
-// CHECK: Terminator:   switch_enum %0 : $Optional<Builtin.NativeObject>, case #Optional.some!enumelt.1: bb1, case #Optional.none!enumelt: bb2
-// CHECK: Argument:   %2 = argument of bb1 : $Builtin.NativeObject
-// CHECK: Expected convention: guaranteed.
-// CHECK: Actual convention:   owned
+// CHECK: Have operand with incompatible ownership?!
+// CHECK: Value: %0 = argument of bb0
+// CHECK: User:   switch_enum %0
+// CHECK: Conv: guaranteed
+// CHECK: OwnershipMap:
+// CHECK: -- OperandOwnershipKindMap --
+// CHECK: trivial:  Yes. Liveness: MustBeLive
+// CHECK: unowned:  No.
+// CHECK: owned: Yes. Liveness: MustBeInvalidated
+// CHECK: guaranteed:  No.
+// CHECK: any: Yes. Liveness: MustBeLive
 sil @switch_enum_mismatching_argument_guaranteed_to_owned : $@convention(thin) (@guaranteed Optional<Builtin.NativeObject>) -> () {
 bb0(%0 : @guaranteed $Optional<Builtin.NativeObject>):
   switch_enum %0 : $Optional<Builtin.NativeObject>, case #Optional.some!enumelt.1: bb1, case #Optional.none!enumelt: bb2
@@ -198,11 +203,17 @@
 }
 
 // CHECK-LABEL: Function: 'switch_enum_mismatching_argument_owned_to_guaranteed'
-// CHECK: Error! Argument ownership kind does not match terminator!
-// CHECK: Terminator:   switch_enum %0 : $Optional<Builtin.NativeObject>, case #Optional.some!enumelt.1: bb1, case #Optional.none!enumelt: bb2
-// CHECK: Argument:   %2 = argument of bb1 : $Builtin.NativeObject
-// CHECK: Expected convention: owned.
-// CHECK: Actual convention: guaranteed
+// CHECK: Have operand with incompatible ownership?!
+// CHECK: Value: %0 = argument of bb0 : $Optional<Builtin.NativeObject>
+// CHECK: User:   switch_enum %0 : $Optional<Builtin.NativeObject>
+// CHECK: Conv: owned
+// CHECK: OwnershipMap:
+// CHECK: -- OperandOwnershipKindMap --
+// CHECK: trivial:  Yes. Liveness: MustBeLive
+// CHECK: unowned:  No.
+// CHECK: owned:  No.
+// CHECK: guaranteed: Yes. Liveness: MustBeLive
+// CHECK: any: Yes. Liveness: MustBeLive
 sil @switch_enum_mismatching_argument_owned_to_guaranteed : $@convention(thin) (@owned Optional<Builtin.NativeObject>) -> () {
 bb0(%0 : @owned $Optional<Builtin.NativeObject>):
   switch_enum %0 : $Optional<Builtin.NativeObject>, case #Optional.some!enumelt.1: bb1, case #Optional.none!enumelt: bb2
@@ -247,18 +258,17 @@
 }
 
 // CHECK-LABEL: Function: 'checked_cast_br_mismatching_argument_guaranteed_to_owned_1'
-// CHECK: Error! Argument ownership kind does not match terminator!
-// CHECK: Terminator:   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
-// CHECK: Argument:   %2 = argument of bb1 : $SuperKlass
-// CHECK: Expected convention: guaranteed.
-// CHECK: Actual convention:   owned
-
-// CHECK-LABEL: Function: 'checked_cast_br_mismatching_argument_guaranteed_to_owned_1'
-// CHECK: Error! Argument ownership kind does not match terminator!
-// CHECK: Terminator:   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
-// CHECK: Argument:   %5 = argument of bb2 : $Builtin.NativeObject
-// CHECK: Expected convention: guaranteed.
-// CHECK: Actual convention:   owned
+// CHECK: Have operand with incompatible ownership?!
+// CHECK: Value: %0 = argument of bb0 : $Builtin.NativeObject
+// CHECK: User:   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
+// CHECK: Conv: guaranteed
+// CHECK: OwnershipMap:
+// CHECK: -- OperandOwnershipKindMap --
+// CHECK: trivial:  No.
+// CHECK: unowned:  No.
+// CHECK: owned: Yes. Liveness: MustBeInvalidated
+// CHECK: guaranteed:  No.
+// CHECK: any: Yes. Liveness: MustBeLive
 sil @checked_cast_br_mismatching_argument_guaranteed_to_owned_1 : $@convention(thin) (@guaranteed Builtin.NativeObject) -> () {
 bb0(%0 : @guaranteed $Builtin.NativeObject):
   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
@@ -277,11 +287,11 @@
 }
 
 // CHECK-LABEL: Function: 'checked_cast_br_mismatching_argument_guaranteed_to_owned_2'
-// CHECK: Error! Argument ownership kind does not match terminator!
-// CHECK: Terminator:   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
-// CHECK: Argument:   %5 = argument of bb2 : $Builtin.NativeObject
-// CHECK: Expected convention: guaranteed.
-// CHECK: Actual convention:   owned
+// CHECK: Ill-formed SIL! Unable to compute ownership kind map for user?!
+// CHECK: For terminator users, check that successors have compatible ownership kinds.
+// CHECK: Value: %0 = argument of bb0 : $Builtin.NativeObject
+// CHECK: User:   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
+// CHECK: Conv: guaranteed
 sil @checked_cast_br_mismatching_argument_guaranteed_to_owned_2 : $@convention(thin) (@guaranteed Builtin.NativeObject) -> () {
 bb0(%0 : @guaranteed $Builtin.NativeObject):
   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
@@ -300,11 +310,11 @@
 }
 
 // CHECK-LABEL: Function: 'checked_cast_br_mismatching_argument_guaranteed_to_owned_3'
-// CHECK: Error! Argument ownership kind does not match terminator!
-// CHECK: Terminator:   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
-// CHECK: Argument:   %2 = argument of bb1 : $SuperKlass
-// CHECK: Expected convention: guaranteed.
-// CHECK: Actual convention:   owned
+// CHECK: Ill-formed SIL! Unable to compute ownership kind map for user?!
+// CHECK: For terminator users, check that successors have compatible ownership kinds.
+// CHECK: Value: %0 = argument of bb0 : $Builtin.NativeObject
+// CHECK: User:   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
+// CHECK: Conv: guaranteed
 sil @checked_cast_br_mismatching_argument_guaranteed_to_owned_3 : $@convention(thin) (@guaranteed Builtin.NativeObject) -> () {
 bb0(%0 : @guaranteed $Builtin.NativeObject):
   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
@@ -323,17 +333,17 @@
 }
 
 // CHECK-LABEL: Function: 'checked_cast_br_mismatching_argument_owned_to_guaranteed_1'
-// CHECK: Error! Argument ownership kind does not match terminator!
-// CHECK: Terminator:   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
-// CHECK: Argument:   %2 = argument of bb1 : $SuperKlass
-// CHECK: Expected convention: owned.
-// CHECK: Actual convention:   guaranteed
-// CHECK-LABEL: Function: 'checked_cast_br_mismatching_argument_owned_to_guaranteed_1'
-// CHECK: Error! Argument ownership kind does not match terminator!
-// CHECK: Terminator:   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
-// CHECK: Argument:   %5 = argument of bb2 : $Builtin.NativeObject
-// CHECK: Expected convention: owned.
-// CHECK: Actual convention:   guaranteed
+// CHECK: Have operand with incompatible ownership?!
+// CHECK: Value: %0 = argument of bb0 : $Builtin.NativeObject
+// CHECK: User:   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
+// CHECK: Conv: owned
+// CHECK: OwnershipMap:
+// CHECK: -- OperandOwnershipKindMap --
+// CHECK: trivial:  No.
+// CHECK: unowned:  No.
+// CHECK: owned:  No.
+// CHECK: guaranteed: Yes. Liveness: MustBeLive
+// CHECK: any: Yes. Liveness: MustBeLive
 sil @checked_cast_br_mismatching_argument_owned_to_guaranteed_1 : $@convention(thin) (@owned Builtin.NativeObject) -> () {
 bb0(%0 : @owned $Builtin.NativeObject):
   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
@@ -353,11 +363,11 @@
 
 
 // CHECK-LABEL: Function: 'checked_cast_br_mismatching_argument_owned_to_guaranteed_2'
-// CHECK: Error! Argument ownership kind does not match terminator!
-// CHECK: Terminator:   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
-// CHECK: Argument:   %2 = argument of bb1 : $SuperKlass
-// CHECK: Expected convention: owned.
-// CHECK: Actual convention:   guaranteed
+// CHECK: Ill-formed SIL! Unable to compute ownership kind map for user?!
+// CHECK: For terminator users, check that successors have compatible ownership kinds.
+// CHECK: Value: %0 = argument of bb0 : $Builtin.NativeObject
+// CHECK: User:   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
+// CHECK: Conv: owned
 sil @checked_cast_br_mismatching_argument_owned_to_guaranteed_2 : $@convention(thin) (@owned Builtin.NativeObject) -> () {
 bb0(%0 : @owned $Builtin.NativeObject):
   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
@@ -376,11 +386,11 @@
 }
 
 // CHECK-LABEL: Function: 'checked_cast_br_mismatching_argument_owned_to_guaranteed_3'
-// CHECK: Error! Argument ownership kind does not match terminator!
-// CHECK: Terminator:   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
-// CHECK: Argument:   %5 = argument of bb2 : $Builtin.NativeObject
-// CHECK: Expected convention: owned.
-// CHECK: Actual convention:   guaranteed
+// CHECK: Ill-formed SIL! Unable to compute ownership kind map for user?!
+// CHECK: For terminator users, check that successors have compatible ownership kinds.
+// CHECK: Value: %0 = argument of bb0 : $Builtin.NativeObject
+// CHECK: User:   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
+// CHECK: Conv: owned
 sil @checked_cast_br_mismatching_argument_owned_to_guaranteed_3 : $@convention(thin) (@owned Builtin.NativeObject) -> () {
 bb0(%0 : @owned $Builtin.NativeObject):
   checked_cast_br %0 : $Builtin.NativeObject to $SuperKlass, bb1, bb2
diff --git a/test/SIL/ownership-verifier/subobject_borrowing.sil b/test/SIL/ownership-verifier/subobject_borrowing.sil
index 94a3c12..54c7012 100644
--- a/test/SIL/ownership-verifier/subobject_borrowing.sil
+++ b/test/SIL/ownership-verifier/subobject_borrowing.sil
@@ -77,7 +77,6 @@
 // CHECK-LABEL: Function: 'value_subobject_with_destroy_of_subobject'
 // CHECK: Have operand with incompatible ownership?!
 // CHECK: Value:   %5 = tuple_extract %4 : $(Builtin.NativeObject, Builtin.NativeObject), 1
-// CHECK: BaseValue:   %1 = begin_borrow %0 : $B
 // CHECK: User:   destroy_value %5 : $Builtin.NativeObject
 // CHECK: Conv: guaranteed
 
@@ -140,7 +139,6 @@
 // CHECK-LABEL: Function: 'funcarg_subobject_with_destroy_of_subobject'
 // CHECK: Have operand with incompatible ownership?!
 // CHECK: Value:   %4 = tuple_extract %3 : $(Builtin.NativeObject, Builtin.NativeObject), 1
-// CHECK: BaseValue:   %0 = argument of bb0 : $B
 // CHECK: User:   destroy_value %4 : $Builtin.NativeObject
 // CHECK: Conv: guaranteed
 sil @funcarg_subobject_with_destroy_of_subobject : $@convention(thin) (@guaranteed B) -> () {
diff --git a/test/SIL/ownership-verifier/use_verifier.sil b/test/SIL/ownership-verifier/use_verifier.sil
index 6639bb1..31762c9 100644
--- a/test/SIL/ownership-verifier/use_verifier.sil
+++ b/test/SIL/ownership-verifier/use_verifier.sil
@@ -101,6 +101,9 @@
   init()
 }
 
+sil @produce_owned_optional : $@convention(thin) () -> @owned Optional<Builtin.NativeObject>
+sil @guaranteed_nativeobject_user : $@convention(thin) (@guaranteed Builtin.NativeObject) -> ()
+
 ////////////////
 // Test Cases //
 ////////////////
@@ -448,6 +451,61 @@
   return %9999 : $()
 }
 
+// Make sure that we can propagate through an argument through an enum that is
+// switched upon and whose payload is then destroyed.
+sil @switch_enum_owned_payload_test2 : $@convention(thin) (@owned Builtin.NativeObject) -> () {
+bb0(%0 : @owned $Builtin.NativeObject):
+  %1 = enum $Optional<Builtin.NativeObject>, #Optional.some!enumelt.1, %0 : $Builtin.NativeObject
+  switch_enum %1 : $Optional<Builtin.NativeObject>, case #Optional.none!enumelt: bb1, case #Optional.some!enumelt.1: bb2
+
+bb1:
+  br bb3
+
+bb2(%2 : @owned $Builtin.NativeObject):
+  destroy_value %2 : $Builtin.NativeObject
+  br bb3
+
+bb3:
+  %9999 = tuple()
+  return %9999 : $()
+}
+
+sil @switch_enum_owned_payload_test3 : $@convention(thin) () -> () {
+bb0:
+  %1 = enum $Optional<Builtin.NativeObject>, #Optional.none!enumelt
+  switch_enum %1 : $Optional<Builtin.NativeObject>, case #Optional.none!enumelt: bb1, case #Optional.some!enumelt.1: bb2
+
+bb1:
+  br bb3
+
+bb2(%2 : @owned $Builtin.NativeObject):
+  destroy_value %2 : $Builtin.NativeObject
+  br bb3
+
+bb3:
+  %9999 = tuple()
+  return %9999 : $()
+}
+
+// Make sure that we can propagate through an argument through an enum that is
+// switched upon and whose payload is then destroyed.
+sil @switch_enum_owned_payload_test4 : $@convention(thin) (@owned Builtin.NativeObject) -> () {
+bb0(%0 : @owned $Builtin.NativeObject):
+  %1 = enum $Optional<Builtin.NativeObject>, #Optional.some!enumelt.1, %0 : $Builtin.NativeObject
+  switch_enum %1 : $Optional<Builtin.NativeObject>, case #Optional.some!enumelt.1: bb2, case #Optional.none!enumelt: bb1
+
+bb1:
+  br bb3
+
+bb2(%2 : @owned $Builtin.NativeObject):
+  destroy_value %2 : $Builtin.NativeObject
+  br bb3
+
+bb3:
+  %9999 = tuple()
+  return %9999 : $()
+}
+
 // Make sure that we can properly handle a guaranteed switch_enum.
 sil @switch_enum_guaranteed_arg_test : $@convention(thin) (@guaranteed Builtin.NativeObject) -> () {
 bb0(%0 : @guaranteed $Builtin.NativeObject):
@@ -1029,3 +1087,28 @@
   %9999 = tuple()
   return %9999 : $()
 }
+
+sil @switch_enum_apply_test : $@convention(thin) () -> @owned Builtin.NativeObject {
+bb0:
+  %0 = function_ref @produce_owned_optional : $@convention(thin) () -> @owned Optional<Builtin.NativeObject>
+  %1 = apply %0() : $@convention(thin) () -> @owned Optional<Builtin.NativeObject>
+  switch_enum %1 : $Optional<Builtin.NativeObject>, case #Optional.some!enumelt.1: bb2, case #Optional.none!enumelt: bb1
+
+bb1:
+  unreachable
+
+bb2(%2 : @owned $Builtin.NativeObject):
+  return %2 : $Builtin.NativeObject
+}
+
+// Make sure that we allow for @owned parameters to be passed as @guaranteed
+// parameters since we are performing an "instantaneous" borrow.
+sil @owned_passed_to_guaranteed_apply_parameter : $@convention(thin) (@owned Builtin.NativeObject) -> () {
+bb0k(%0 : @owned $Builtin.NativeObject):
+  %1 = function_ref @guaranteed_nativeobject_user : $@convention(thin) (@guaranteed Builtin.NativeObject) -> ()
+  apply %1(%0) : $@convention(thin) (@guaranteed Builtin.NativeObject) -> ()
+  destroy_value %0 : $Builtin.NativeObject
+  %9999 = tuple()
+  return %9999 : $()
+}
+
diff --git a/test/SILOptimizer/semantic-arc-opts.sil b/test/SILOptimizer/semantic-arc-opts.sil
index 0e0e3d0..7e54ab9 100644
--- a/test/SILOptimizer/semantic-arc-opts.sil
+++ b/test/SILOptimizer/semantic-arc-opts.sil
@@ -1,4 +1,4 @@
-// RUN: %target-sil-opt -enable-sil-verify-all -enable-sil-ownership -semantic-arc-opts %s | %FileCheck %s
+// RUN: %target-sil-opt -module-name Swift -enable-sil-verify-all -enable-sil-ownership -semantic-arc-opts %s | %FileCheck %s
 
 sil_stage canonical
 
diff --git a/test/api-digester/Inputs/cake.swift b/test/api-digester/Inputs/cake.swift
index aff628b..6c38d61 100644
--- a/test/api-digester/Inputs/cake.swift
+++ b/test/api-digester/Inputs/cake.swift
@@ -49,6 +49,8 @@
   public var a = 1
   private var b = 2
   var c = 3
+  @available(*, unavailable)
+  public let unavailableProperty = 1
 }
 
 extension Int: P1 { public func bar() {} }
@@ -84,3 +86,5 @@
 public extension P1 {
   static func +(lhs: P1, rhs: P1) -> P1 { return lhs }
 }
+
+infix operator ..*..
diff --git a/test/api-digester/Inputs/cake1.swift b/test/api-digester/Inputs/cake1.swift
index 214b5fd..ef50ca8 100644
--- a/test/api-digester/Inputs/cake1.swift
+++ b/test/api-digester/Inputs/cake1.swift
@@ -55,6 +55,12 @@
   public var a = 1
 }
 
+@_fixed_layout
+public struct fixedLayoutStruct2 {
+  public private(set) var NoLongerWithFixedBinaryOrder = 1
+  public var BecomeFixedBinaryOrder: Int { return 1 }
+}
+
 @_frozen
 public enum FrozenKind {
   case Unchanged
diff --git a/test/api-digester/Inputs/cake2.swift b/test/api-digester/Inputs/cake2.swift
index 8dad5c2..1a5da27 100644
--- a/test/api-digester/Inputs/cake2.swift
+++ b/test/api-digester/Inputs/cake2.swift
@@ -59,6 +59,12 @@
   private lazy var lazy_d = 4
 }
 
+@_fixed_layout
+public struct fixedLayoutStruct2 {
+  public var NoLongerWithFixedBinaryOrder: Int { return 1 }
+  public var BecomeFixedBinaryOrder = 1
+}
+
 @_frozen
 public enum FrozenKind {
   case Unchanged
diff --git a/test/api-digester/stdlib-stable.json b/test/api-digester/Inputs/stdlib-stable-abi.json
similarity index 70%
copy from test/api-digester/stdlib-stable.json
copy to test/api-digester/Inputs/stdlib-stable-abi.json
index 9c07404..798d8e3 100644
--- a/test/api-digester/stdlib-stable.json
+++ b/test/api-digester/Inputs/stdlib-stable-abi.json
@@ -7,308 +7,306 @@
       "kind": "Function",
       "name": "min",
       "printedName": "min(_:_:)",
-      "declKind": "Func",
-      "usr": "s:s3minyxx_xtSLRzlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Comparable>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s3minyxx_xtSLRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "min",
       "printedName": "min(_:_:_:_:)",
-      "declKind": "Func",
-      "usr": "s:s3minyxx_xxxdtSLRzlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Comparable>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "Array",
-          "printedName": "[T]",
-          "usr": "s:Sa",
+          "printedName": "Array<τ_0_0>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "usr": "s:Sa"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s3minyxx_xxxdtSLRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "max",
       "printedName": "max(_:_:)",
-      "declKind": "Func",
-      "usr": "s:s3maxyxx_xtSLRzlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Comparable>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s3maxyxx_xtSLRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "max",
       "printedName": "max(_:_:_:_:)",
-      "declKind": "Func",
-      "usr": "s:s3maxyxx_xxxdtSLRzlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Comparable>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "Array",
-          "printedName": "[T]",
-          "usr": "s:Sa",
+          "printedName": "Array<τ_0_0>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "usr": "s:Sa"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s3maxyxx_xxxdtSLRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "EnumeratedSequence",
       "printedName": "EnumeratedSequence",
-      "declKind": "Struct",
-      "usr": "s:s18EnumeratedSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Sequence>",
-      "conformingProtocols": [
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
+          "kind": "Var",
+          "name": "_base",
+          "printedName": "_base",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s18EnumeratedSequenceV5_basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s18EnumeratedSequenceV5_basexvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s18EnumeratedSequenceV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "conformingProtocols": [
-            "IteratorProtocol",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s18EnumeratedSequenceV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
+              "kind": "Var",
+              "name": "_base",
+              "printedName": "_base",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(offset: Int, element: Base.Element)",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Iterator"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Iterator"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s18EnumeratedSequenceV8IteratorV5_baseACQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s18EnumeratedSequenceV8IteratorV5_baseACQzvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_count",
+              "printedName": "_count",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Int",
                       "printedName": "Int",
                       "usr": "s:Si"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Base.Element"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s18EnumeratedSequenceV8IteratorV6_countSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s18EnumeratedSequenceV8IteratorV6_countSivp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 1,
+              "hasStorage": true
             },
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s18EnumeratedSequenceV8IteratorV4nextSi6offset_7ElementQz7elementtSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "EnumeratedSequence<Base>.Iterator.Element?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "EnumeratedSequence<Base>.Iterator.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Tuple",
-                          "printedName": "(offset: Int, element: τ_0_0.Element)",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Int",
-                              "printedName": "Int",
-                              "usr": "s:Si"
-                            },
-                            {
-                              "kind": "TypeNominal",
-                              "name": "DependentMember",
-                              "printedName": "τ_0_0.Element"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s18EnumeratedSequenceV8IteratorVACa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "EnumeratedSequence<Base>.Iterator",
-                  "usr": "s:s18EnumeratedSequenceV8IteratorV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s18EnumeratedSequenceV8IteratorV03SubB0a",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnySequence",
-                  "printedName": "AnySequence<(offset: Int, element: Base.Element)>",
-                  "usr": "s:s11AnySequenceV",
+                  "printedName": "Optional<(offset: Int, element: τ_0_0.Element)>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Tuple",
-                      "printedName": "(offset: Int, element: Base.Element)",
+                      "printedName": "(offset: Int, element: τ_0_0.Element)",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -319,116 +317,1346 @@
                         {
                           "kind": "TypeNominal",
                           "name": "DependentMember",
-                          "printedName": "Base.Element"
+                          "printedName": "τ_0_0.Element"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s18EnumeratedSequenceV8IteratorV4nextSi6offset_7ElementQz7elementtSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s18EnumeratedSequenceV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "Sequence"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s18EnumeratedSequenceV12makeIteratorAB0D0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Iterator",
-              "printedName": "EnumeratedSequence<Base>.Iterator",
+              "printedName": "EnumeratedSequence<τ_0_0>.Iterator",
               "usr": "s:s18EnumeratedSequenceV8IteratorV"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s18EnumeratedSequenceV7Elementa",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s18EnumeratedSequenceV12makeIteratorAB0D0Vyx_GyF",
           "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(offset: Int, element: Base.Element)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s18EnumeratedSequenceV03SubB0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnySequence",
-              "printedName": "AnySequence<(offset: Int, element: Base.Element)>",
-              "usr": "s:s11AnySequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(offset: Int, element: Base.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Base.Element"
-                    }
-                  ]
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s18EnumeratedSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Array",
       "printedName": "Array",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_buffer",
+          "printedName": "_buffer",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "_ArrayBuffer",
+              "printedName": "_ArrayBuffer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s12_ArrayBufferV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_ArrayBuffer",
+                  "printedName": "_ArrayBuffer<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:s12_ArrayBufferV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sa7_buffers12_ArrayBufferVyxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sa7_buffers12_ArrayBufferVyxGvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sa10startIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sa10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sa8endIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sa8endIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa5index5afterS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa9formIndex5afterySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa5index6beforeS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa9formIndex6beforeySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa5index_8offsetByS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:limitedBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa5index_8offsetBy07limitedC0SiSgSi_S2itF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(from:to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa8distance4from2toS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SayxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ArraySlice",
+              "printedName": "ArraySlice<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s10ArraySliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Says10ArraySliceVyxGSnySiGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(arrayLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sa"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sa"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sa12arrayLiteralSayxGxd_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sa"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:S2ayxGycfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sa"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SaySayxGqd__c7ElementQyd__RszSTRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(repeating:count:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sa"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sa9repeating5countSayxGx_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "count",
+          "printedName": "count",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sa5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sa5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "capacity",
+          "printedName": "capacity",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sa8capacitySivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sa8capacitySivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "reserveCapacity",
+          "printedName": "reserveCapacity(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa15reserveCapacityyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "append",
+          "printedName": "append(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa6appendyyxnF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "append",
+          "printedName": "append(contentsOf:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa6append10contentsOfyqd__n_t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "remove",
+          "printedName": "remove(at:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa6remove2atxSi_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "insert",
+          "printedName": "insert(_:at:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa6insert_2atyxn_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "removeAll",
+          "printedName": "removeAll(keepingCapacity:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "hasDefaultArg": true,
+              "usr": "s:Sb"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa9removeAll15keepingCapacityySb_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Var",
+          "name": "customMirror",
+          "printedName": "customMirror",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Mirror",
+              "printedName": "Mirror",
+              "usr": "s:s6MirrorV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sa12customMirrors0B0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sa12customMirrors0B0Vvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "description",
+          "printedName": "description",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sa11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sa11descriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sa16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sa16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeBufferPointer",
+          "printedName": "withUnsafeBufferPointer(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafeBufferPointer<τ_0_0>) throws -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeBufferPointer",
+                  "printedName": "UnsafeBufferPointer<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:SR"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa23withUnsafeBufferPointeryqd__qd__SRyxGKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeMutableBufferPointer",
+          "printedName": "withUnsafeMutableBufferPointer(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(inout UnsafeMutableBufferPointer<τ_0_0>) throws -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "InOut",
+                  "printedName": "inout UnsafeMutableBufferPointer<τ_0_0>"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa30withUnsafeMutableBufferPointeryqd__qd__SryxGzKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inline",
+            "Semantics"
+          ],
+          "throwing": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "replaceSubrange",
+          "printedName": "replaceSubrange(_:with:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa15replaceSubrange_4withySnySiG_qd__nt7ElementQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : Collection>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sa"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sa"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SasSQRzlE2eeoiySbSayxG_ABtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Equatable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "hash",
+          "printedName": "hash(into:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Hasher",
+              "printedName": "Hasher",
+              "usr": "s:s6HasherV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SasSHRzlE4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "hashValue",
+          "printedName": "hashValue",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SasSHRzlE9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+              "implicit": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SasSHRzlE9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeMutableBytes",
+          "printedName": "withUnsafeMutableBytes(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafeMutableRawBufferPointer) throws -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutableRawBufferPointer",
+                  "printedName": "UnsafeMutableRawBufferPointer",
+                  "usr": "s:Sw"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa22withUnsafeMutableBytesyqd__qd__SwKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeBytes",
+          "printedName": "withUnsafeBytes(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafeRawBufferPointer) throws -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeRawBufferPointer",
+                  "printedName": "UnsafeRawBufferPointer",
+                  "usr": "s:SW"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa15withUnsafeBytesyqd__qd__SWKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SasSERzlE6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable>",
+          "throwing": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sa"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SasSeRzlE4fromSayxGs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable>",
+          "throwing": true
+        }
+      ],
       "declKind": "Struct",
       "usr": "s:Sa",
-      "location": "",
       "moduleName": "Swift",
-      "genericSig": "<Element>",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "_DestructorSafeContainer",
         "RandomAccessCollection",
@@ -448,593 +1676,545 @@
         "Encodable",
         "Decodable",
         "_HasContiguousBytes"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "ArraySlice",
+      "printedName": "ArraySlice",
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:Sa5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:Sa7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Int>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:Sa8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "IndexingIterator",
-              "printedName": "IndexingIterator<Array<Element>>",
-              "usr": "s:s16IndexingIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Array",
-                  "printedName": "Array<Element>",
-                  "usr": "s:Sa",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
           "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:Sa10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "name": "_buffer",
+          "printedName": "_buffer",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sa10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
+              "name": "_SliceBuffer",
+              "printedName": "_SliceBuffer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:Sa8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sa8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "declAttributes": [
-                "Inlinable"
               ],
+              "usr": "s:s12_SliceBufferV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:Sa5index5afterS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:Sa9formIndex5afterySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:Sa5index6beforeS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:Sa9formIndex6beforeySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:Sa5index_8offsetByS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:Sa5index_8offsetBy07limitedC0SiSgSi_S2itF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:Sa8distance4from2toS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:Sa7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:Sa11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ArraySlice",
-              "printedName": "ArraySlice<Element>",
-              "usr": "s:s10ArraySliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(arrayLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Sa12arrayLiteralSayxGxd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "Array<Element>",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "[Array<Element>.Element]",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Array<Element>.Element",
+                  "name": "_SliceBuffer",
+                  "printedName": "_SliceBuffer<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s12_SliceBufferV"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10ArraySliceV7_buffers01_B6BufferVyxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10ArraySliceV7_buffers01_B6BufferVyxGvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10ArraySliceV10startIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10ArraySliceV10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "TypeAlias",
-          "name": "ArrayLiteralElement",
-          "printedName": "ArrayLiteralElement",
-          "declKind": "TypeAlias",
-          "usr": "s:Sa19ArrayLiteralElementa",
-          "location": "",
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10ArraySliceV8endIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10ArraySliceV8endIndexSivp",
           "moduleName": "Swift",
-          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV5index5afterS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV9formIndex5afterySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV5index6beforeS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV9formIndex6beforeySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV5index_8offsetByS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:limitedBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV5index_8offsetBy07limitedE0SiSgSi_S2itF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(from:to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV8distance4from2toS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Element"
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s10ArraySliceVyxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ArraySlice",
+              "printedName": "ArraySlice<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s10ArraySliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s10ArraySliceVyAByxGSnySiGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(arrayLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ArraySlice",
+              "printedName": "ArraySlice<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s10ArraySliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sa"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s10ArraySliceV12arrayLiteralAByxGxd_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:S2ayxGycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "Array<Element>",
-              "usr": "s:Sa",
+              "name": "ArraySlice",
+              "printedName": "ArraySlice<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s10ArraySliceV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s10ArraySliceVAByxGycfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SaySayxGqd__c7ElementQyd__RszSTRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "Array<Element>",
-              "usr": "s:Sa",
+              "name": "ArraySlice",
+              "printedName": "ArraySlice<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s10ArraySliceV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "S"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s10ArraySliceVyAByxGqd__c7ElementQyd__RszSTRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(repeating:count:)",
-          "declKind": "Constructor",
-          "usr": "s:Sa9repeating5countSayxGx_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "Array<Element>",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "Array<Element>.Element",
+              "name": "ArraySlice",
+              "printedName": "ArraySlice<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s10ArraySliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -1042,19 +2222,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s10ArraySliceV9repeating5countAByxGx_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:Sa5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -1066,11 +2247,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sa5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -1078,21 +2254,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10ArraySliceV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10ArraySliceV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "capacity",
           "printedName": "capacity",
-          "declKind": "Var",
-          "usr": "s:Sa8capacitySivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -1104,11 +2283,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sa8capacitySivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -1116,24 +2290,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10ArraySliceV8capacitySivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10ArraySliceV8capacitySivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "reserveCapacity",
           "printedName": "reserveCapacity(_:)",
-          "declKind": "Func",
-          "usr": "s:Sa15reserveCapacityyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -1146,56 +2320,21 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV15reserveCapacityyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(_:)",
-          "declKind": "Func",
-          "usr": "s:Sa6appendyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "Array<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "append",
-          "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:Sa6append10contentsOfyqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -1205,58 +2344,23 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "S"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV6appendyyxnF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
-          "name": "remove",
-          "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:Sa6remove2atxSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "Array<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "insert",
-          "printedName": "insert(_:at:)",
-          "declKind": "Func",
-          "usr": "s:Sa6insert_2atyx_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "name": "append",
+          "printedName": "append(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -1264,16 +2368,30 @@
               "printedName": "()"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "Array<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV6append10contentsOfyqd__n_t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "remove",
+          "printedName": "remove(at:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -1281,21 +2399,52 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV6remove2atxSi_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "insert",
+          "printedName": "insert(_:at:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV6insert_2atyxn_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeAll",
           "printedName": "removeAll(keepingCapacity:)",
-          "declKind": "Func",
-          "usr": "s:Sa9removeAll15keepingCapacityySb_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -1309,16 +2458,20 @@
               "hasDefaultArg": true,
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV9removeAll15keepingCapacityySb_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Sa12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -1330,11 +2483,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sa12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -1342,18 +2490,21 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10ArraySliceV12customMirrors0D0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s10ArraySliceV12customMirrors0D0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:Sa11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -1365,11 +2516,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sa11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -1377,18 +2523,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10ArraySliceV11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s10ArraySliceV11descriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Sa16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -1400,11 +2549,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sa16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -1412,140 +2556,113 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10ArraySliceV16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s10ArraySliceV16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "withUnsafeBufferPointer",
           "printedName": "withUnsafeBufferPointer(_:)",
-          "declKind": "Func",
-          "usr": "s:Sa23withUnsafeBufferPointeryqd__qd__SRyxGKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "R"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(UnsafeBufferPointer<Array<Element>.Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(UnsafeBufferPointer<τ_0_0>) throws -> τ_1_0",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "R"
+                  "printedName": "τ_1_0"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeBufferPointer<Array<Element>.Element>)",
-                  "usr": "s:SR",
+                  "name": "UnsafeBufferPointer",
+                  "printedName": "UnsafeBufferPointer<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "UnsafeBufferPointer",
-                      "printedName": "UnsafeBufferPointer<Array<Element>.Element>",
-                      "usr": "s:SR",
-                      "children": [
-                        {
-                          "kind": "TypeNameAlias",
-                          "name": "Element",
-                          "printedName": "Array<Element>.Element",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GenericTypeParam",
-                              "printedName": "τ_0_0"
-                            }
-                          ]
-                        }
-                      ]
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:SR"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV23withUnsafeBufferPointeryqd__qd__SRyxGKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "withUnsafeMutableBufferPointer",
           "printedName": "withUnsafeMutableBufferPointer(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(inout UnsafeMutableBufferPointer<τ_0_0>) throws -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "InOut",
+                  "printedName": "inout UnsafeMutableBufferPointer<τ_0_0>"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
           "declKind": "Func",
-          "usr": "s:Sa30withUnsafeMutableBufferPointeryqd__qd__SryxGzKXEKlF",
-          "location": "",
+          "usr": "s:s10ArraySliceV30withUnsafeMutableBufferPointeryqd__qd__SryxGzKXEKlF",
           "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "mutating": true,
+          "genericSig": "<τ_0_0, τ_1_0>",
           "declAttributes": [
             "Rethrows",
             "Inline",
             "Semantics"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(inout UnsafeMutableBufferPointer<Array<Element>.Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(inout UnsafeMutableBufferPointer<Array<Element>.Element>)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "InOut",
-                      "printedName": "inout UnsafeMutableBufferPointer<Array<Element>.Element>"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "replaceSubrange",
           "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:Sa15replaceSubrange_4withySnySiG_qd__t7ElementQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, C where Element == C.Element, C : Collection>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -1556,7 +2673,6 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Int>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -1564,27 +2680,76 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "C"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV15replaceSubrange_4withySnySiG_qd__nt7ElementQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : Collection>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ArraySlice",
+              "printedName": "ArraySlice<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s10ArraySliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ArraySlice",
+              "printedName": "ArraySlice<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s10ArraySliceV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceVsSQRzlE2eeoiySbAByxG_ADtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Equatable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SasSHRzlE4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -1597,16 +2762,19 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceVsSHRzlE4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SasSHRzlE9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -1618,11 +2786,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SasSHRzlE9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -1630,186 +2793,112 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10ArraySliceVsSHRzlE9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s10ArraySliceVsSHRzlE9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "withUnsafeMutableBytes",
           "printedName": "withUnsafeMutableBytes(_:)",
-          "declKind": "Func",
-          "usr": "s:Sa22withUnsafeMutableBytesyqd__qd__SwKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "R"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(UnsafeMutableRawBufferPointer) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(UnsafeMutableRawBufferPointer) throws -> τ_1_0",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "R"
+                  "printedName": "τ_1_0"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeMutableRawBufferPointer)",
-                  "usr": "s:Sw",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeMutableRawBufferPointer",
-                      "printedName": "UnsafeMutableRawBufferPointer",
-                      "usr": "s:Sw"
-                    }
-                  ]
+                  "name": "UnsafeMutableRawBufferPointer",
+                  "printedName": "UnsafeMutableRawBufferPointer",
+                  "usr": "s:Sw"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV22withUnsafeMutableBytesyqd__qd__SwKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "withUnsafeBytes",
           "printedName": "withUnsafeBytes(_:)",
-          "declKind": "Func",
-          "usr": "s:Sa15withUnsafeBytesyqd__qd__SWKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "R"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(UnsafeRawBufferPointer) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(UnsafeRawBufferPointer) throws -> τ_1_0",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "R"
+                  "printedName": "τ_1_0"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeRawBufferPointer)",
-                  "usr": "s:SW",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeRawBufferPointer",
-                      "printedName": "UnsafeRawBufferPointer",
-                      "usr": "s:SW"
-                    }
-                  ]
+                  "name": "UnsafeRawBufferPointer",
+                  "printedName": "UnsafeRawBufferPointer",
+                  "usr": "s:SW"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(to:)",
+          ],
           "declKind": "Func",
-          "usr": "s:SasSERzlE6encode2toys7Encoder_p_tKF",
-          "location": "",
+          "usr": "s:s10ArraySliceV15withUnsafeBytesyqd__qd__SWKXEKlF",
           "moduleName": "Swift",
-          "genericSig": "<Element where Element : Encodable>",
-          "throwing": true,
+          "genericSig": "<τ_0_0, τ_1_0>",
           "declAttributes": [
+            "Rethrows",
             "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:SasSeRzlE4fromSayxGs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Decodable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "Array<Element>",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "throwing": true
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "ArraySlice",
-      "printedName": "ArraySlice",
+      ],
       "declKind": "Struct",
       "usr": "s:s10ArraySliceV",
-      "location": "",
       "moduleName": "Swift",
-      "genericSig": "<Element>",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "_DestructorSafeContainer",
         "RandomAccessCollection",
@@ -1825,1305 +2914,12 @@
         "CustomDebugStringConvertible",
         "Equatable",
         "Hashable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s10ArraySliceV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s10ArraySliceV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Int>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s10ArraySliceV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "IndexingIterator",
-              "printedName": "IndexingIterator<ArraySlice<Element>>",
-              "usr": "s:s16IndexingIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "ArraySlice",
-                  "printedName": "ArraySlice<Element>",
-                  "usr": "s:s10ArraySliceV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s10ArraySliceV10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10ArraySliceV10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s10ArraySliceV8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10ArraySliceV8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV5index5afterS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV9formIndex5afterySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV5index6beforeS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV9formIndex6beforeySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV5index_8offsetByS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV5index_8offsetBy07limitedE0SiSgSi_S2itF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV8distance4from2toS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s10ArraySliceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s10ArraySliceV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ArraySlice",
-              "printedName": "ArraySlice<Element>",
-              "usr": "s:s10ArraySliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(arrayLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s10ArraySliceV12arrayLiteralAByxGxd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ArraySlice",
-              "printedName": "ArraySlice<Element>",
-              "usr": "s:s10ArraySliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "[ArraySlice<Element>.Element]",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "ArraySlice<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "ArrayLiteralElement",
-          "printedName": "ArrayLiteralElement",
-          "declKind": "TypeAlias",
-          "usr": "s:s10ArraySliceV0A14LiteralElementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s10ArraySliceVAByxGycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ArraySlice",
-              "printedName": "ArraySlice<Element>",
-              "usr": "s:s10ArraySliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s10ArraySliceVyAByxGqd__c7ElementQyd__RszSTRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ArraySlice",
-              "printedName": "ArraySlice<Element>",
-              "usr": "s:s10ArraySliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(repeating:count:)",
-          "declKind": "Constructor",
-          "usr": "s:s10ArraySliceV9repeating5countAByxGx_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ArraySlice",
-              "printedName": "ArraySlice<Element>",
-              "usr": "s:s10ArraySliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "ArraySlice<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "count",
-          "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s10ArraySliceV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10ArraySliceV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "capacity",
-          "printedName": "capacity",
-          "declKind": "Var",
-          "usr": "s:s10ArraySliceV8capacitySivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10ArraySliceV8capacitySivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "reserveCapacity",
-          "printedName": "reserveCapacity(_:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV15reserveCapacityyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "append",
-          "printedName": "append(_:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV6appendyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "ArraySlice<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "append",
-          "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV6append10contentsOfyqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "remove",
-          "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV6remove2atxSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "ArraySlice<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "insert",
-          "printedName": "insert(_:at:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV6insert_2atyx_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "ArraySlice<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "removeAll",
-          "printedName": "removeAll(keepingCapacity:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV9removeAll15keepingCapacityySb_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "hasDefaultArg": true,
-              "usr": "s:Sb"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s10ArraySliceV12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10ArraySliceV12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "description",
-          "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:s10ArraySliceV11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10ArraySliceV11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "debugDescription",
-          "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s10ArraySliceV16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10ArraySliceV16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeBufferPointer",
-          "printedName": "withUnsafeBufferPointer(_:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV23withUnsafeBufferPointeryqd__qd__SRyxGKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafeBufferPointer<ArraySlice<Element>.Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeBufferPointer<ArraySlice<Element>.Element>)",
-                  "usr": "s:SR",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeBufferPointer",
-                      "printedName": "UnsafeBufferPointer<ArraySlice<Element>.Element>",
-                      "usr": "s:SR",
-                      "children": [
-                        {
-                          "kind": "TypeNameAlias",
-                          "name": "Element",
-                          "printedName": "ArraySlice<Element>.Element",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GenericTypeParam",
-                              "printedName": "τ_0_0"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeMutableBufferPointer",
-          "printedName": "withUnsafeMutableBufferPointer(_:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV30withUnsafeMutableBufferPointeryqd__qd__SryxGzKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inline",
-            "Semantics"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(inout UnsafeMutableBufferPointer<ArraySlice<Element>.Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(inout UnsafeMutableBufferPointer<ArraySlice<Element>.Element>)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "InOut",
-                      "printedName": "inout UnsafeMutableBufferPointer<ArraySlice<Element>.Element>"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "replaceSubrange",
-          "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV15replaceSubrange_4withySnySiG_qd__t7ElementQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, C where Element == C.Element, C : Collection>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Int>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "C"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "hash",
-          "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceVsSHRzlE4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Hasher",
-              "printedName": "Hasher",
-              "usr": "s:s6HasherV"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "hashValue",
-          "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s10ArraySliceVsSHRzlE9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10ArraySliceVsSHRzlE9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeMutableBytes",
-          "printedName": "withUnsafeMutableBytes(_:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV22withUnsafeMutableBytesyqd__qd__SwKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafeMutableRawBufferPointer) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeMutableRawBufferPointer)",
-                  "usr": "s:Sw",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeMutableRawBufferPointer",
-                      "printedName": "UnsafeMutableRawBufferPointer",
-                      "usr": "s:Sw"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeBytes",
-          "printedName": "withUnsafeBytes(_:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV15withUnsafeBytesyqd__qd__SWKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafeRawBufferPointer) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeRawBufferPointer)",
-                  "usr": "s:SW",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeRawBufferPointer",
-                      "printedName": "UnsafeRawBufferPointer",
-                      "usr": "s:SW"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        }
       ]
     },
     {
       "kind": "Function",
       "name": "assert",
       "printedName": "assert(_:_:file:line:)",
-      "declKind": "Func",
-      "usr": "s:s6assert__4file4lineySbyXK_SSyXKs12StaticStringVSutF",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Transparent"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -3134,9 +2930,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "() -> Bool",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3149,15 +2942,15 @@
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         },
         {
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "() -> String",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3170,6 +2963,9 @@
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         },
         {
@@ -3186,19 +2982,18 @@
           "hasDefaultArg": true,
           "usr": "s:Su"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s6assert__4file4lineySbyXK_SSyXKs12StaticStringVSutF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Transparent"
       ]
     },
     {
       "kind": "Function",
       "name": "precondition",
       "printedName": "precondition(_:_:file:line:)",
-      "declKind": "Func",
-      "usr": "s:s12precondition__4file4lineySbyXK_SSyXKs12StaticStringVSutF",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Transparent"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -3209,9 +3004,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "() -> Bool",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3224,15 +3016,15 @@
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         },
         {
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "() -> String",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3245,6 +3037,9 @@
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         },
         {
@@ -3261,20 +3056,18 @@
           "hasDefaultArg": true,
           "usr": "s:Su"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s12precondition__4file4lineySbyXK_SSyXKs12StaticStringVSutF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Transparent"
       ]
     },
     {
       "kind": "Function",
       "name": "assertionFailure",
       "printedName": "assertionFailure(_:file:line:)",
-      "declKind": "Func",
-      "usr": "s:s16assertionFailure_4file4lineySSyXK_s12StaticStringVSutF",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Inline",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -3285,9 +3078,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "() -> String",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3300,6 +3090,9 @@
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         },
         {
@@ -3316,19 +3109,19 @@
           "hasDefaultArg": true,
           "usr": "s:Su"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s16assertionFailure_4file4lineySSyXK_s12StaticStringVSutF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inline",
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "preconditionFailure",
       "printedName": "preconditionFailure(_:file:line:)",
-      "declKind": "Func",
-      "usr": "s:s19preconditionFailure_4file4lines5NeverOSSyXK_s12StaticStringVSutF",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Transparent"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -3340,9 +3133,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "() -> String",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3355,6 +3145,9 @@
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         },
         {
@@ -3371,19 +3164,18 @@
           "hasDefaultArg": true,
           "usr": "s:Su"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s19preconditionFailure_4file4lines5NeverOSSyXK_s12StaticStringVSutF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Transparent"
       ]
     },
     {
       "kind": "Function",
       "name": "fatalError",
       "printedName": "fatalError(_:file:line:)",
-      "declKind": "Func",
-      "usr": "s:s10fatalError_4file4lines5NeverOSSyXK_s12StaticStringVSutF",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Transparent"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -3395,9 +3187,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "() -> String",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3410,6 +3199,9 @@
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         },
         {
@@ -3426,53 +3218,85 @@
           "hasDefaultArg": true,
           "usr": "s:Su"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s10fatalError_4file4lines5NeverOSSyXK_s12StaticStringVSutF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Transparent"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "BidirectionalCollection",
       "printedName": "BidirectionalCollection",
-      "declKind": "Protocol",
-      "usr": "s:SK",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Collection, Self.Indices : BidirectionalCollection, Self.SubSequence : BidirectionalCollection>",
-      "conformingProtocols": [
-        "Collection",
-        "Sequence"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Element",
+          "printedName": "Element",
+          "declKind": "AssociatedType",
+          "usr": "s:SK7ElementQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Index",
+          "printedName": "Index",
+          "declKind": "AssociatedType",
+          "usr": "s:SK5IndexQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "declKind": "AssociatedType",
+          "usr": "s:SK11SubSequenceQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Indices",
+          "printedName": "Indices",
+          "declKind": "AssociatedType",
+          "usr": "s:SK7IndicesQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:SK5index6before5IndexQzAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SK5index6before5IndexQzAD_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:SK9formIndex6beforey0B0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -3482,41 +3306,45 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SK9formIndex6beforey0B0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:SK5index5after5IndexQzAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SK5index5after5IndexQzAD_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:SK9formIndex5aftery0B0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -3526,29 +3354,33 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SK9formIndex5aftery0B0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SK5index_8offsetBy5IndexQzAD_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
@@ -3556,35 +3388,35 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SK5index_8offsetBy5IndexQzAD_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SK5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Index?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
@@ -3595,19 +3427,19 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SK5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SK8distance4from2toSi5IndexQz_AEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -3618,176 +3450,252 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SK8distance4from2toSi5IndexQz_AEtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:SK7indices7IndicesQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Indices"
+              "printedName": "τ_0_0.Indices"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SK7indices7IndicesQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Indices"
+                  "printedName": "τ_0_0.Indices"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SK7indices7IndicesQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+              "overriding": true,
+              "declAttributes": [
+                "Override"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SK7indices7IndicesQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Var",
           "name": "last",
           "printedName": "last",
-          "declKind": "Var",
-          "usr": "s:SK4last7ElementQzSgvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SK4last7ElementQzSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Self.Element?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<τ_0_0.Element>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Element"
+                      "printedName": "τ_0_0.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SK4last7ElementQzSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SK4last7ElementQzSgvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.SubSequence"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SKy11SubSequenceQzSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SKy7ElementQz5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:SK10startIndex0B0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SK10startIndex0B0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SK10startIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+              "overriding": true,
+              "declAttributes": [
+                "Override"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SK10startIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:SK8endIndex0B0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SK8endIndex0B0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SK8endIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+              "overriding": true,
+              "declAttributes": [
+                "Override"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SK8endIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:SKsE9formIndex6beforey0B0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3797,32 +3705,32 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE9formIndex6beforey0B0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SKsE5index_8offsetBy5IndexQzAD_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
@@ -3830,38 +3738,37 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE5index_8offsetBy5IndexQzAD_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SKsE5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Index?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
@@ -3872,22 +3779,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SKsE8distance4from2toSi5IndexQz_AEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3898,79 +3804,75 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE8distance4from2toSi5IndexQz_AEtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "popLast",
           "printedName": "popLast()",
-          "declKind": "Func",
-          "usr": "s:SKs11SubSequenceQzRszrlE7popLast7ElementQzSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SKs11SubSequenceQzRszrlE7popLast7ElementQzSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0 == τ_0_0.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeLast",
           "printedName": "removeLast()",
-          "declKind": "Func",
-          "usr": "s:SKs11SubSequenceQzRszrlE10removeLast7ElementQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SKs11SubSequenceQzRszrlE10removeLast7ElementQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0 == τ_0_0.SubSequence>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeLast",
           "printedName": "removeLast(_:)",
-          "declKind": "Func",
-          "usr": "s:SKs11SubSequenceQzRszrlE10removeLastyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3983,25 +3885,25 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SKs11SubSequenceQzRszrlE10removeLastyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0 == τ_0_0.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:SKsE8dropLasty11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
@@ -4009,25 +3911,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE8dropLasty11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:SKsE6suffixy11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
@@ -4035,95 +3936,87 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE6suffixy11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "last",
           "printedName": "last",
-          "declKind": "Var",
-          "usr": "s:SKsE4last7ElementQzSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SKsE4last7ElementQzSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Self.Element?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<τ_0_0.Element>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Element"
+                      "printedName": "τ_0_0.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SKsE4last7ElementQzSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SKsE4last7ElementQzSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "last",
           "printedName": "last(where:)",
-          "declKind": "Func",
-          "usr": "s:SKsE4last5where7ElementQzSgSbADKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -4133,55 +4026,47 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE4last5where7ElementQzSgSbADKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "lastIndex",
           "printedName": "lastIndex(where:)",
-          "declKind": "Func",
-          "usr": "s:SKsE9lastIndex5where0B0QzSgSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Index?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -4191,93 +4076,88 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE9lastIndex5where0B0QzSgSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "lastIndex",
           "printedName": "lastIndex(of:)",
-          "declKind": "Func",
-          "usr": "s:SKsSQ7ElementRpzrlE9lastIndex2of0C0QzSgAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self.Element : Equatable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Index?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsSQ7ElementRpzrlE9lastIndex2of0C0QzSgAB_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0.Element : Equatable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "reversed",
           "printedName": "reversed()",
-          "declKind": "Func",
-          "usr": "s:SKsE8reverseds18ReversedCollectionVyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ReversedCollection",
-              "printedName": "ReversedCollection<Self>",
-              "usr": "s:s18ReversedCollectionV",
+              "printedName": "ReversedCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s18ReversedCollectionV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE8reverseds18ReversedCollectionVyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "joined",
           "printedName": "joined(separator:)",
-          "declKind": "Func",
-          "usr": "s:SKsSS7ElementRtzrlE6joined9separatorS2S_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self.Element == String>",
-          "declAttributes": [
-            "Specialize"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4292,99 +4172,120 @@
               "hasDefaultArg": true,
               "usr": "s:SS"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsSS7ElementRtzrlE6joined9separatorS2S_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0.Element == String>",
+          "declAttributes": [
+            "Specialize"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SK",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : Collection, τ_0_0.Indices : BidirectionalCollection, τ_0_0.SubSequence : BidirectionalCollection>",
+      "conformingProtocols": [
+        "Collection",
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Bool",
       "printedName": "Bool",
-      "declKind": "Struct",
-      "usr": "s:Sb",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "_ExpressibleByBuiltinBooleanLiteral",
-        "ExpressibleByBooleanLiteral",
-        "CustomStringConvertible",
-        "Equatable",
-        "Hashable",
-        "LosslessStringConvertible",
-        "Decodable",
-        "Encodable",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:S2bycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
+          "kind": "Var",
+          "name": "_value",
+          "printedName": "_value",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SbySbBi1_cfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "UsableFromInline"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
+              "name": "BuiltinInteger",
+              "printedName": "Builtin.Int1"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Int1",
-              "printedName": "Int1",
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "BuiltinInteger",
                   "printedName": "Builtin.Int1"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sb6_valueBi1_vg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sb6_valueBi1_vp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:S2bycfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SbyS2bcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "BuiltinInteger",
+              "printedName": "Builtin.Int1"
+            }
           ],
+          "declKind": "Constructor",
+          "usr": "s:SbySbBi1_cfc",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "Transparent",
+            "UsableFromInline"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -4398,21 +4299,18 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SbyS2bcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "random",
           "printedName": "random(using:)",
-          "declKind": "Func",
-          "usr": "s:Sb6random5usingSbxz_tSGRzlFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T where T : RandomNumberGenerator>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4423,22 +4321,22 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb6random5usingSbxz_tSGRzlFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RandomNumberGenerator>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "random",
           "printedName": "random()",
-          "declKind": "Func",
-          "usr": "s:Sb6randomSbyFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4446,19 +4344,19 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb6randomSbyFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(booleanLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Sb14booleanLiteralS2b_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4472,36 +4370,18 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "BooleanLiteralType",
-          "printedName": "BooleanLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Sb18BooleanLiteralTypea",
-          "location": "",
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sb14booleanLiteralS2b_tcfc",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            }
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:Sb11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4513,10 +4393,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sb11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -4524,21 +4400,55 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sb11descriptionSSvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sb11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb2eeoiyS2b_SbtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:Sb4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4551,16 +4461,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Sb9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -4572,10 +4484,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sb9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -4583,27 +4491,27 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sb9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sb9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SbySbSgSScfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Bool?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Bool>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -4611,7 +4519,8 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -4619,40 +4528,164 @@
               "printedName": "String",
               "usr": "s:SS"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SbySbSgSScfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
+          "name": "!",
+          "printedName": "!(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb1nopyS2bFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&&",
+          "printedName": "&&(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "() throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb2aaoiyS2b_SbyKXKtKFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Rethrows",
+            "Inline",
+            "Transparent"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "||",
+          "printedName": "||(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "() throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb2oooiyS2b_SbyKXKtKFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Rethrows",
+            "Inline",
+            "Transparent"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
           "name": "toggle",
           "printedName": "toggle()",
-          "declKind": "Func",
-          "usr": "s:Sb6toggleyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb6toggleyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:Sb4fromSbs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4666,20 +4699,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sb4fromSbs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:Sb6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4692,16 +4721,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Sb12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -4713,10 +4742,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sb12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -4724,23 +4749,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sb12customMirrors0B0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sb12customMirrors0B0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:Sb25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4752,10 +4774,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sb25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -4763,84 +4781,117 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sb25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sb25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:Sb",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "_ExpressibleByBuiltinBooleanLiteral",
+        "ExpressibleByBooleanLiteral",
+        "CustomStringConvertible",
+        "Equatable",
+        "Hashable",
+        "LosslessStringConvertible",
+        "Encodable",
+        "Decodable",
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AutoreleasingUnsafeMutablePointer",
       "printedName": "AutoreleasingUnsafeMutablePointer",
-      "declKind": "Struct",
-      "usr": "s:SA",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Pointee>",
-      "conformingProtocols": [
-        "_Pointer",
-        "Hashable",
-        "Strideable",
-        "CustomDebugStringConvertible",
-        "CustomReflectable",
-        "Equatable",
-        "Comparable",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
-          "name": "pointee",
-          "printedName": "pointee",
-          "declKind": "Var",
-          "usr": "s:SA7pointeexvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "name": "_rawValue",
+          "printedName": "_rawValue",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Pointee"
+              "name": "BuiltinRawPointer",
+              "printedName": "Builtin.RawPointer"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinRawPointer",
+                  "printedName": "Builtin.RawPointer"
+                }
+              ],
               "declKind": "Accessor",
-              "usr": "s:SA7pointeexvg",
-              "location": "",
+              "usr": "s:SA9_rawValueBpvg",
               "moduleName": "Swift",
-              "genericSig": "<Pointee>",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
               "declAttributes": [
                 "Transparent"
-              ],
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SA9_rawValueBpvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "pointee",
+          "printedName": "pointee",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Pointee"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SA7pointeexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Setter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SA7pointeexvs",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Pointee>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -4850,137 +4901,154 @@
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Pointee"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SA7pointeexvs",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SAySAyxGSPyqd__Gclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee, U>",
-          "declAttributes": [
-            "Transparent",
-            "UsableFromInline"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AutoreleasingUnsafeMutablePointer",
-              "printedName": "AutoreleasingUnsafeMutablePointer<Pointee>",
-              "usr": "s:SA",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Pointee"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafePointer",
-              "printedName": "UnsafePointer<U>",
-              "usr": "s:SP",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "U"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SAySAyxGSgSPyqd__GSgclufc",
-          "location": "",
+          "declKind": "Var",
+          "usr": "s:SA7pointeexvp",
           "moduleName": "Swift",
-          "genericSig": "<Pointee, U>",
           "declAttributes": [
-            "Transparent",
-            "UsableFromInline"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "AutoreleasingUnsafeMutablePointer<Pointee>?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AutoreleasingUnsafeMutablePointer",
-                  "printedName": "AutoreleasingUnsafeMutablePointer<Pointee>",
-                  "usr": "s:SA",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Pointee"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UnsafePointer<U>?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafePointer",
-                  "printedName": "UnsafePointer<U>",
-                  "usr": "s:SP",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "U"
-                    }
-                  ]
-                }
-              ]
-            }
+            "Inlinable"
           ]
         },
         {
-          "kind": "TypeAlias",
-          "name": "Pointee",
-          "printedName": "Pointee",
-          "declKind": "TypeAlias",
-          "usr": "s:SA7Pointeea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Pointee"
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SAyxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "AutoreleasingUnsafeMutablePointer",
+              "printedName": "AutoreleasingUnsafeMutablePointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SA"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafePointer",
+              "printedName": "UnsafePointer<τ_1_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                }
+              ],
+              "usr": "s:SP"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SAySAyxGSPyqd__Gclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "isInternal": true,
+          "declAttributes": [
+            "Transparent",
+            "UsableFromInline"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<AutoreleasingUnsafeMutablePointer<τ_0_0>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "AutoreleasingUnsafeMutablePointer",
+                  "printedName": "AutoreleasingUnsafeMutablePointer<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:SA"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<UnsafePointer<τ_1_0>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafePointer",
+                  "printedName": "UnsafePointer<τ_1_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_1_0"
+                    }
+                  ],
+                  "usr": "s:SP"
+                }
+              ],
+              "usr": "s:Sq"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SAySAyxGSgSPyqd__GSgclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "isInternal": true,
+          "declAttributes": [
+            "Transparent",
+            "UsableFromInline"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SA9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -4992,11 +5060,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SA9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Pointee>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -5004,201 +5067,1319 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SA9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:SA6Stridea",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:SA9hashValueSivp",
           "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:SA",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "_Pointer",
+        "Hashable",
+        "Strideable",
+        "CustomDebugStringConvertible",
+        "CustomReflectable",
+        "Equatable",
+        "Comparable",
+        "CVarArg"
       ]
     },
     {
       "kind": "Function",
       "name": "unsafeBitCast",
       "printedName": "unsafeBitCast(_:to:)",
-      "declKind": "Func",
-      "usr": "s:s13unsafeBitCast_2toq_x_q_mtr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, U>",
-      "declAttributes": [
-        "Transparent",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "U"
+          "printedName": "τ_0_1"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "Metatype",
-          "printedName": "U.Type",
+          "printedName": "τ_0_1.Type",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "U"
+              "printedName": "τ_0_1"
             }
           ]
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s13unsafeBitCast_2toq_x_q_mtr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1>",
+      "declAttributes": [
+        "Transparent",
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "==",
+      "printedName": "==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "Optional<Any.Type>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ExistentialMetatype",
+              "printedName": "Any.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ProtocolComposition",
+                  "printedName": "Any"
+                }
+              ]
+            }
+          ],
+          "usr": "s:Sq"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "Optional<Any.Type>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ExistentialMetatype",
+              "printedName": "Any.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ProtocolComposition",
+                  "printedName": "Any"
+                }
+              ]
+            }
+          ],
+          "usr": "s:Sq"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2eeoiySbypXpSg_ABtF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "Optional<Any.Type>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ExistentialMetatype",
+              "printedName": "Any.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ProtocolComposition",
+                  "printedName": "Any"
+                }
+              ]
+            }
+          ],
+          "usr": "s:Sq"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "Optional<Any.Type>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ExistentialMetatype",
+              "printedName": "Any.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ProtocolComposition",
+                  "printedName": "Any"
+                }
+              ]
+            }
+          ],
+          "usr": "s:Sq"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbypXpSg_ABtF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "unsafeDowncast",
       "printedName": "unsafeDowncast(_:to:)",
-      "declKind": "Func",
-      "usr": "s:s14unsafeDowncast_2toxyXl_xmtRlzClF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : AnyObject>",
-      "declAttributes": [
-        "Transparent"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
-          "kind": "TypeNameAlias",
-          "name": "AnyObject",
-          "printedName": "AnyObject",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ProtocolComposition",
-              "printedName": "AnyObject"
-            }
-          ]
+          "kind": "TypeNominal",
+          "name": "ProtocolComposition",
+          "printedName": "AnyObject"
         },
         {
           "kind": "TypeNominal",
           "name": "Metatype",
-          "printedName": "T.Type",
+          "printedName": "τ_0_0.Type",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_0_0"
             }
           ]
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s14unsafeDowncast_2toxyXl_xmtRlzClF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : AnyObject>",
+      "declAttributes": [
+        "Transparent"
       ]
     },
     {
       "kind": "Function",
       "name": "type",
       "printedName": "type(of:)",
-      "declKind": "Func",
-      "usr": "s:s4type2ofq_x_tr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, Metatype>",
-      "declAttributes": [
-        "Semantics",
-        "Transparent"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "Metatype"
+          "printedName": "τ_0_1"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s4type2ofq_x_tr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1>",
+      "declAttributes": [
+        "Semantics",
+        "Transparent"
       ]
     },
     {
       "kind": "Function",
       "name": "withoutActuallyEscaping",
       "printedName": "withoutActuallyEscaping(_:do:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_1"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeFunc",
+          "name": "Function",
+          "printedName": "(τ_0_0) throws -> τ_0_1",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "typeAttributes": [
+            "noescape"
+          ]
+        }
+      ],
       "declKind": "Func",
       "usr": "s:s23withoutActuallyEscaping_2doq_x_q_xKXEtKr0_lF",
-      "location": "",
       "moduleName": "Swift",
-      "genericSig": "<ClosureType, ResultType>",
-      "throwing": true,
+      "genericSig": "<τ_0_0, τ_0_1>",
       "declAttributes": [
         "Rethrows",
         "Semantics",
         "Transparent"
       ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "ResultType"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "ClosureType"
-        },
-        {
-          "kind": "TypeFunc",
-          "name": "Function",
-          "printedName": "(ClosureType) throws -> ResultType",
-          "typeAttributes": [
-            "noescape"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "ResultType"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Paren",
-              "printedName": "(ClosureType)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "ClosureType"
-                }
-              ]
-            }
-          ]
-        }
-      ]
+      "throwing": true
     },
     {
       "kind": "TypeDecl",
       "name": "Character",
       "printedName": "Character",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_representation",
+          "printedName": "_representation",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Representation",
+              "printedName": "Character.Representation",
+              "usr": "s:SJ14RepresentationO"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Representation",
+                  "printedName": "Character.Representation",
+                  "usr": "s:SJ14RepresentationO"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SJ15_representationSJ14RepresentationOvg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SJ15_representationSJ14RepresentationOvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Scalar",
+              "printedName": "Unicode.Scalar",
+              "usr": "s:s7UnicodeO6ScalarV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SJySJs7UnicodeO6ScalarVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(extendedGraphemeClusterLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SJ30extendedGraphemeClusterLiteralS2J_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SJySJSScfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "description",
+          "printedName": "description",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SJ11descriptionSSvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SJ11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SJ16debugDescriptionSSvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SJ16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SJ2eeoiySbSJ_SJtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SJ1loiySbSJ_SJtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "hash",
+          "printedName": "hash(into:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Hasher",
+              "printedName": "Hasher",
+              "usr": "s:s6HasherV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SJ4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Effects"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "hashValue",
+          "printedName": "hashValue",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SJ9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SJ9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "UnicodeScalarView",
+          "printedName": "UnicodeScalarView",
+          "children": [
+            {
+              "kind": "Var",
+              "name": "_base",
+              "printedName": "_base",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Character",
+                  "printedName": "Character",
+                  "usr": "s:SJ"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Character",
+                      "printedName": "Character",
+                      "usr": "s:SJ"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SJ17UnicodeScalarViewV5_baseSJvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SJ17UnicodeScalarViewV5_baseSJvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "isLet": true,
+              "hasStorage": true
+            },
+            {
+              "kind": "TypeDecl",
+              "name": "Iterator",
+              "printedName": "Iterator",
+              "children": [
+                {
+                  "kind": "Var",
+                  "name": "_base",
+                  "printedName": "_base",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "IndexingIterator",
+                      "printedName": "IndexingIterator<Character.UnicodeScalarView>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UnicodeScalarView",
+                          "printedName": "Character.UnicodeScalarView",
+                          "usr": "s:SJ17UnicodeScalarViewV"
+                        }
+                      ],
+                      "usr": "s:s16IndexingIteratorV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "IndexingIterator",
+                          "printedName": "IndexingIterator<Character.UnicodeScalarView>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UnicodeScalarView",
+                              "printedName": "Character.UnicodeScalarView",
+                              "usr": "s:SJ17UnicodeScalarViewV"
+                            }
+                          ],
+                          "usr": "s:s16IndexingIteratorV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SJ17UnicodeScalarViewV8IteratorV5_bases08IndexingD0VyABGvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SJ17UnicodeScalarViewV8IteratorV5_bases08IndexingD0VyABGvp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 0,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Function",
+                  "name": "next",
+                  "printedName": "next()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<Unicode.Scalar>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Scalar",
+                          "printedName": "Unicode.Scalar",
+                          "usr": "s:s7UnicodeO6ScalarV"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SJ17UnicodeScalarViewV8IteratorV4nexts0A0O0B0VSgyF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ],
+                  "mutating": true
+                }
+              ],
+              "declKind": "Struct",
+              "usr": "s:SJ17UnicodeScalarViewV8IteratorV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "IteratorProtocol"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "makeIterator",
+              "printedName": "makeIterator()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Iterator",
+                  "printedName": "Character.UnicodeScalarView.Iterator",
+                  "usr": "s:SJ17UnicodeScalarViewV8IteratorV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SJ17UnicodeScalarViewV12makeIteratorAB0E0VyF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "TypeDecl",
+              "name": "Index",
+              "printedName": "Index",
+              "children": [
+                {
+                  "kind": "Var",
+                  "name": "_encodedOffset",
+                  "printedName": "_encodedOffset",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Int",
+                          "printedName": "Int",
+                          "usr": "s:Si"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SJ17UnicodeScalarViewV5IndexV14_encodedOffsetSivg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV14_encodedOffsetSivp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 0,
+                  "isLet": true,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Var",
+                  "name": "_scalar",
+                  "printedName": "_scalar",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_UIntBuffer",
+                      "printedName": "_UIntBuffer<UInt32, UInt16>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UInt32",
+                          "printedName": "UInt32",
+                          "usr": "s:s6UInt32V"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UInt16",
+                          "printedName": "UInt16",
+                          "usr": "s:s6UInt16V"
+                        }
+                      ],
+                      "usr": "s:s11_UIntBufferV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "_UIntBuffer",
+                          "printedName": "_UIntBuffer<UInt32, UInt16>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt32",
+                              "printedName": "UInt32",
+                              "usr": "s:s6UInt32V"
+                            },
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt16",
+                              "printedName": "UInt16",
+                              "usr": "s:s6UInt16V"
+                            }
+                          ],
+                          "usr": "s:s11_UIntBufferV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SJ17UnicodeScalarViewV5IndexV7_scalars11_UIntBufferVys6UInt32Vs6UInt16VGvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV7_scalars11_UIntBufferVys6UInt32Vs6UInt16VGvp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 1,
+                  "isLet": true,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Var",
+                  "name": "_stride",
+                  "printedName": "_stride",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt8",
+                      "printedName": "UInt8",
+                      "usr": "s:s5UInt8V"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UInt8",
+                          "printedName": "UInt8",
+                          "usr": "s:s5UInt8V"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SJ17UnicodeScalarViewV5IndexV7_strides5UInt8Vvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV7_strides5UInt8Vvp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 2,
+                  "isLet": true,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Function",
+                  "name": "==",
+                  "printedName": "==(_:_:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Character.UnicodeScalarView.Index",
+                      "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Character.UnicodeScalarView.Index",
+                      "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV2eeoiySbAD_ADtFZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "<",
+                  "printedName": "<(_:_:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Character.UnicodeScalarView.Index",
+                      "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Character.UnicodeScalarView.Index",
+                      "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV1loiySbAD_ADtFZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                }
+              ],
+              "declKind": "Struct",
+              "usr": "s:SJ17UnicodeScalarViewV5IndexV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "Equatable",
+                "Comparable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "startIndex",
+              "printedName": "startIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Character.UnicodeScalarView.Index",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Character.UnicodeScalarView.Index",
+                      "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SJ17UnicodeScalarViewV10startIndexAB0E0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SJ17UnicodeScalarViewV10startIndexAB0E0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "endIndex",
+              "printedName": "endIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Character.UnicodeScalarView.Index",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Character.UnicodeScalarView.Index",
+                      "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SJ17UnicodeScalarViewV8endIndexAB0E0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SJ17UnicodeScalarViewV8endIndexAB0E0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Character.UnicodeScalarView.Index",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Character.UnicodeScalarView.Index",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SJ17UnicodeScalarViewV5index5afterAB5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Scalar",
+                  "printedName": "Unicode.Scalar",
+                  "usr": "s:s7UnicodeO6ScalarV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Character.UnicodeScalarView.Index",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SJ17UnicodeScalarViewVys0A0O0B0VAB5IndexVcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(before:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Character.UnicodeScalarView.Index",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Character.UnicodeScalarView.Index",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SJ17UnicodeScalarViewV5index6beforeAB5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SJ17UnicodeScalarViewV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "Sequence",
+            "Collection",
+            "BidirectionalCollection"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "unicodeScalars",
+          "printedName": "unicodeScalars",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnicodeScalarView",
+              "printedName": "Character.UnicodeScalarView",
+              "usr": "s:SJ17UnicodeScalarViewV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnicodeScalarView",
+                  "printedName": "Character.UnicodeScalarView",
+                  "usr": "s:SJ17UnicodeScalarViewV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SJ14unicodeScalarsSJ17UnicodeScalarViewVvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SJ14unicodeScalarsSJ17UnicodeScalarViewVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "customMirror",
+          "printedName": "customMirror",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Mirror",
+              "printedName": "Mirror",
+              "usr": "s:s6MirrorV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SJ12customMirrors0B0Vvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SJ12customMirrors0B0Vvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "customPlaygroundQuickLook",
+          "printedName": "customPlaygroundQuickLook",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "_PlaygroundQuickLook",
+              "printedName": "_PlaygroundQuickLook",
+              "usr": "s:s20_PlaygroundQuickLookO"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_PlaygroundQuickLook",
+                  "printedName": "_PlaygroundQuickLook",
+                  "usr": "s:s20_PlaygroundQuickLookO"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SJ25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SJ25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "write",
+          "printedName": "write(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SJ5write2toyxz_ts16TextOutputStreamRzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : TextOutputStream>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        }
+      ],
       "declKind": "Struct",
       "usr": "s:SJ",
-      "location": "",
       "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "_ExpressibleByBuiltinUTF16ExtendedGraphemeClusterLiteral",
         "ExpressibleByExtendedGraphemeClusterLiteral",
@@ -5214,734 +6395,17 @@
         "CustomReflectable",
         "_CustomPlaygroundQuickLookable",
         "TextOutputStreamable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SJySJs7UnicodeO6ScalarVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Scalar",
-              "printedName": "Unicode.Scalar",
-              "usr": "s:s7UnicodeO6ScalarV"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(extendedGraphemeClusterLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:SJ30extendedGraphemeClusterLiteralS2J_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SJySJSScfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "ExtendedGraphemeClusterLiteralType",
-          "printedName": "ExtendedGraphemeClusterLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:SJ34ExtendedGraphemeClusterLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "UnicodeScalarLiteralType",
-          "printedName": "UnicodeScalarLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:SJ24UnicodeScalarLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "description",
-          "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:SJ11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SJ11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "debugDescription",
-          "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:SJ16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SJ16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "hash",
-          "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SJ4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Effects"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Hasher",
-              "printedName": "Hasher",
-              "usr": "s:s6HasherV"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "hashValue",
-          "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SJ9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SJ9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeDecl",
-          "name": "UnicodeScalarView",
-          "printedName": "UnicodeScalarView",
-          "declKind": "Struct",
-          "usr": "s:SJ17UnicodeScalarViewV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "Sequence",
-            "Collection",
-            "BidirectionalCollection"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "TypeDecl",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "Struct",
-              "usr": "s:SJ17UnicodeScalarViewV8IteratorV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "IteratorProtocol"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
-              "children": [
-                {
-                  "kind": "Function",
-                  "name": "next",
-                  "printedName": "next()",
-                  "declKind": "Func",
-                  "usr": "s:SJ17UnicodeScalarViewV8IteratorV4nexts0A0O0B0VSgyF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "mutating": true,
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Optional",
-                      "printedName": "UnicodeScalar?",
-                      "usr": "s:Sq",
-                      "children": [
-                        {
-                          "kind": "TypeNameAlias",
-                          "name": "UnicodeScalar",
-                          "printedName": "UnicodeScalar",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Scalar",
-                              "printedName": "Unicode.Scalar",
-                              "usr": "s:s7UnicodeO6ScalarV"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeAlias",
-                  "name": "Element",
-                  "printedName": "Element",
-                  "declKind": "TypeAlias",
-                  "usr": "s:SJ17UnicodeScalarViewV8IteratorV7Elementa",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Scalar",
-                      "printedName": "Unicode.Scalar",
-                      "usr": "s:s7UnicodeO6ScalarV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "makeIterator",
-              "printedName": "makeIterator()",
-              "declKind": "Func",
-              "usr": "s:SJ17UnicodeScalarViewV12makeIteratorAB0E0VyF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "Character.UnicodeScalarView.Iterator",
-                  "usr": "s:SJ17UnicodeScalarViewV8IteratorV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeDecl",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "Struct",
-              "usr": "s:SJ17UnicodeScalarViewV5IndexV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "Equatable",
-                "Comparable"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "startIndex",
-              "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:SJ17UnicodeScalarViewV10startIndexAB0E0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Character.UnicodeScalarView.Index",
-                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SJ17UnicodeScalarViewV10startIndexAB0E0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "Character.UnicodeScalarView.Index",
-                      "usr": "s:SJ17UnicodeScalarViewV5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "endIndex",
-              "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:SJ17UnicodeScalarViewV8endIndexAB0E0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Character.UnicodeScalarView.Index",
-                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SJ17UnicodeScalarViewV8endIndexAB0E0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "Character.UnicodeScalarView.Index",
-                      "usr": "s:SJ17UnicodeScalarViewV5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SJ17UnicodeScalarViewV5index5afterAB5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Character.UnicodeScalarView.Index",
-                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Character.UnicodeScalarView.Index",
-                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:SJ17UnicodeScalarViewV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "UnicodeScalar",
-                  "printedName": "UnicodeScalar",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Scalar",
-                      "printedName": "Unicode.Scalar",
-                      "usr": "s:s7UnicodeO6ScalarV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:SJ17UnicodeScalarViewV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Slice",
-                  "printedName": "Slice<Character.UnicodeScalarView>",
-                  "usr": "s:s5SliceV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnicodeScalarView",
-                      "printedName": "Character.UnicodeScalarView",
-                      "usr": "s:SJ17UnicodeScalarViewV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:SJ17UnicodeScalarViewV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DefaultIndices",
-                  "printedName": "DefaultIndices<Character.UnicodeScalarView>",
-                  "usr": "s:SI",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnicodeScalarView",
-                      "printedName": "Character.UnicodeScalarView",
-                      "usr": "s:SJ17UnicodeScalarViewV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:SJ17UnicodeScalarViewV5index6beforeAB5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Character.UnicodeScalarView.Index",
-                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Character.UnicodeScalarView.Index",
-                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "unicodeScalars",
-          "printedName": "unicodeScalars",
-          "declKind": "Var",
-          "usr": "s:SJ14unicodeScalarsSJ17UnicodeScalarViewVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnicodeScalarView",
-              "printedName": "Character.UnicodeScalarView",
-              "usr": "s:SJ17UnicodeScalarViewV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SJ14unicodeScalarsSJ17UnicodeScalarViewVvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnicodeScalarView",
-                  "printedName": "Character.UnicodeScalarView",
-                  "usr": "s:SJ17UnicodeScalarViewV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:SJ12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SJ12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customPlaygroundQuickLook",
-          "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:SJ25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "_PlaygroundQuickLook",
-              "printedName": "_PlaygroundQuickLook",
-              "usr": "s:s20_PlaygroundQuickLookO"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SJ25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "_PlaygroundQuickLook",
-                  "printedName": "_PlaygroundQuickLook",
-                  "usr": "s:s20_PlaygroundQuickLookO"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "write",
-          "printedName": "write(to:)",
-          "declKind": "Func",
-          "usr": "s:SJ5write2toyxz_ts16TextOutputStreamRzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Target where Target : TextOutputStream>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Target"
-            }
-          ]
-        }
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Encodable",
       "printedName": "Encodable",
-      "declKind": "Protocol",
-      "usr": "s:SE",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:SE6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encodable>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -5954,34 +6418,33 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SE6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable>",
+          "protocolReq": true,
+          "throwing": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SE",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "Decodable",
       "printedName": "Decodable",
-      "declKind": "Protocol",
-      "usr": "s:Se",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:Se4fromxs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -5989,48 +6452,28 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Se4fromxs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable>",
+          "protocolReq": true,
+          "throwing": true
         }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "Codable",
-      "printedName": "Codable",
-      "declKind": "TypeAlias",
-      "usr": "s:s7Codablea",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ProtocolComposition",
-          "printedName": "Decodable & Encodable"
-        }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:Se",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "CodingKey",
       "printedName": "CodingKey",
-      "declKind": "Protocol",
-      "usr": "s:s9CodingKeyP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : CustomDebugStringConvertible, Self : CustomStringConvertible>",
-      "conformingProtocols": [
-        "CustomStringConvertible",
-        "CustomDebugStringConvertible"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "stringValue",
           "printedName": "stringValue",
-          "declKind": "Var",
-          "usr": "s:s9CodingKeyP11stringValueSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -6042,11 +6485,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s9CodingKeyP11stringValueSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6054,32 +6492,35 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s9CodingKeyP11stringValueSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s9CodingKeyP11stringValueSSvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(stringValue:)",
-          "declKind": "Constructor",
-          "usr": "s:s9CodingKeyP11stringValuexSgSS_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : CodingKey>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -6087,22 +6528,22 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s9CodingKeyP11stringValuexSgSS_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "intValue",
           "printedName": "intValue",
-          "declKind": "Var",
-          "usr": "s:s9CodingKeyP8intValueSiSgvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6110,23 +6551,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s9CodingKeyP8intValueSiSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Int?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<Int>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -6134,34 +6570,38 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s9CodingKeyP8intValueSiSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s9CodingKeyP8intValueSiSgvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(intValue:)",
-          "declKind": "Constructor",
-          "usr": "s:s9CodingKeyP8intValuexSgSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : CodingKey>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -6169,19 +6609,17 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s9CodingKeyP8intValuexSgSi_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:s9CodingKeyPsE11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -6193,11 +6631,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s9CodingKeyPsE11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6205,18 +6638,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s9CodingKeyPsE11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s9CodingKeyPsE11descriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s9CodingKeyPsE16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -6228,11 +6664,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s9CodingKeyPsE16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6240,35 +6671,41 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s9CodingKeyPsE16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s9CodingKeyPsE16debugDescriptionSSvp",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s9CodingKeyP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : CustomDebugStringConvertible, τ_0_0 : CustomStringConvertible>",
+      "conformingProtocols": [
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Encoder",
       "printedName": "Encoder",
-      "declKind": "Protocol",
-      "usr": "s:s7EncoderP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s7EncoderP10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[CodingKey]",
-              "usr": "s:Sa",
+              "printedName": "Array<CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6276,23 +6713,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7EncoderP10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Encoder>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<CodingKey>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -6300,26 +6732,30 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7EncoderP10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Encoder>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s7EncoderP10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "userInfo",
           "printedName": "userInfo",
-          "declKind": "Var",
-          "usr": "s:s7EncoderP8userInfoSDys010CodingUserC3KeyVypGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Dictionary",
-              "printedName": "[CodingUserInfoKey : Any]",
-              "usr": "s:SD",
+              "printedName": "Dictionary<CodingUserInfoKey, Any>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6332,23 +6768,18 @@
                   "name": "ProtocolComposition",
                   "printedName": "Any"
                 }
-              ]
+              ],
+              "usr": "s:SD"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7EncoderP8userInfoSDys010CodingUserC3KeyVypGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Encoder>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Dictionary",
-                  "printedName": "[CodingUserInfoKey : Any]",
-                  "usr": "s:SD",
+                  "printedName": "Dictionary<CodingUserInfoKey, Any>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -6361,58 +6792,62 @@
                       "name": "ProtocolComposition",
                       "printedName": "Any"
                     }
-                  ]
+                  ],
+                  "usr": "s:SD"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7EncoderP8userInfoSDys010CodingUserC3KeyVypGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Encoder>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s7EncoderP8userInfoSDys010CodingUserC3KeyVypGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "container",
           "printedName": "container(keyedBy:)",
-          "declKind": "Func",
-          "usr": "s:s7EncoderP9container7keyedBys22KeyedEncodingContainerVyqd__Gqd__m_ts9CodingKeyRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Key where Self : Encoder, Key : CodingKey>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedEncodingContainer",
-              "printedName": "KeyedEncodingContainer<Key>",
-              "usr": "s:s22KeyedEncodingContainerV",
+              "printedName": "KeyedEncodingContainer<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Key"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedEncodingContainerV"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "Key.Type",
+              "printedName": "τ_1_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Key"
+                  "printedName": "τ_1_0"
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7EncoderP9container7keyedBys22KeyedEncodingContainerVyqd__Gqd__m_ts9CodingKeyRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Encoder, τ_1_0 : CodingKey>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "unkeyedContainer",
           "printedName": "unkeyedContainer()",
-          "declKind": "Func",
-          "usr": "s:s7EncoderP16unkeyedContainers015UnkeyedEncodingC0_pyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encoder>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -6420,17 +6855,17 @@
               "printedName": "UnkeyedEncodingContainer",
               "usr": "s:s24UnkeyedEncodingContainerP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7EncoderP16unkeyedContainers015UnkeyedEncodingC0_pyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Encoder>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "singleValueContainer",
           "printedName": "singleValueContainer()",
-          "declKind": "Func",
-          "usr": "s:s7EncoderP20singleValueContainers06Singlec8EncodingD0_pyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encoder>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -6438,33 +6873,32 @@
               "printedName": "SingleValueEncodingContainer",
               "usr": "s:s28SingleValueEncodingContainerP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7EncoderP20singleValueContainers06Singlec8EncodingD0_pyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Encoder>",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s7EncoderP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "Decoder",
       "printedName": "Decoder",
-      "declKind": "Protocol",
-      "usr": "s:s7DecoderP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s7DecoderP10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[CodingKey]",
-              "usr": "s:Sa",
+              "printedName": "Array<CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6472,23 +6906,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7DecoderP10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Decoder>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<CodingKey>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -6496,26 +6925,30 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7DecoderP10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Decoder>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s7DecoderP10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "userInfo",
           "printedName": "userInfo",
-          "declKind": "Var",
-          "usr": "s:s7DecoderP8userInfoSDys010CodingUserC3KeyVypGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Dictionary",
-              "printedName": "[CodingUserInfoKey : Any]",
-              "usr": "s:SD",
+              "printedName": "Dictionary<CodingUserInfoKey, Any>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6528,23 +6961,18 @@
                   "name": "ProtocolComposition",
                   "printedName": "Any"
                 }
-              ]
+              ],
+              "usr": "s:SD"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7DecoderP8userInfoSDys010CodingUserC3KeyVypGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Decoder>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Dictionary",
-                  "printedName": "[CodingUserInfoKey : Any]",
-                  "usr": "s:SD",
+                  "printedName": "Dictionary<CodingUserInfoKey, Any>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -6557,60 +6985,63 @@
                       "name": "ProtocolComposition",
                       "printedName": "Any"
                     }
-                  ]
+                  ],
+                  "usr": "s:SD"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7DecoderP8userInfoSDys010CodingUserC3KeyVypGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Decoder>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s7DecoderP8userInfoSDys010CodingUserC3KeyVypGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "container",
           "printedName": "container(keyedBy:)",
-          "declKind": "Func",
-          "usr": "s:s7DecoderP9container7keyedBys22KeyedDecodingContainerVyqd__Gqd__m_tKs9CodingKeyRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Key where Self : Decoder, Key : CodingKey>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedDecodingContainer",
-              "printedName": "KeyedDecodingContainer<Key>",
-              "usr": "s:s22KeyedDecodingContainerV",
+              "printedName": "KeyedDecodingContainer<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Key"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedDecodingContainerV"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "Key.Type",
+              "printedName": "τ_1_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Key"
+                  "printedName": "τ_1_0"
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7DecoderP9container7keyedBys22KeyedDecodingContainerVyqd__Gqd__m_tKs9CodingKeyRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Decoder, τ_1_0 : CodingKey>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "unkeyedContainer",
           "printedName": "unkeyedContainer()",
-          "declKind": "Func",
-          "usr": "s:s7DecoderP16unkeyedContainers015UnkeyedDecodingC0_pyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decoder>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6618,18 +7049,18 @@
               "printedName": "UnkeyedDecodingContainer",
               "usr": "s:s24UnkeyedDecodingContainerP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7DecoderP16unkeyedContainers015UnkeyedDecodingC0_pyKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Decoder>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "singleValueContainer",
           "printedName": "singleValueContainer()",
-          "declKind": "Func",
-          "usr": "s:s7DecoderP20singleValueContainers06Singlec8DecodingD0_pyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decoder>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6637,34 +7068,42 @@
               "printedName": "SingleValueDecodingContainer",
               "usr": "s:s28SingleValueDecodingContainerP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7DecoderP20singleValueContainers06Singlec8DecodingD0_pyKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Decoder>",
+          "protocolReq": true,
+          "throwing": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s7DecoderP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "KeyedEncodingContainerProtocol",
       "printedName": "KeyedEncodingContainerProtocol",
-      "declKind": "Protocol",
-      "usr": "s:s30KeyedEncodingContainerProtocolP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self.Key : CodingKey>",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Key",
+          "printedName": "Key",
+          "declKind": "AssociatedType",
+          "usr": "s:s30KeyedEncodingContainerProtocolP3KeyQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s30KeyedEncodingContainerProtocolP10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[CodingKey]",
-              "usr": "s:Sa",
+              "printedName": "Array<CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6672,23 +7111,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s30KeyedEncodingContainerProtocolP10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<CodingKey>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -6696,23 +7130,25 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s30KeyedEncodingContainerProtocolP10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s30KeyedEncodingContainerProtocolP10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "encodeNil",
           "printedName": "encodeNil(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP9encodeNil6forKeyy0H0Qz_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6722,21 +7158,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP9encodeNil6forKeyy0H0Qz_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySb_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6752,21 +7188,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySb_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySS_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6782,21 +7218,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySS_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySd_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6812,21 +7248,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySd_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySf_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6842,21 +7278,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySf_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySi_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6872,21 +7308,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySi_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys4Int8V_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6902,21 +7338,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys4Int8V_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys5Int16V_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6932,21 +7368,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys5Int16V_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys5Int32V_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6962,21 +7398,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys5Int32V_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys5Int64V_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6992,21 +7428,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys5Int64V_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySu_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7022,21 +7458,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySu_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys5UInt8V_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7052,21 +7488,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys5UInt8V_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys6UInt16V_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7082,21 +7518,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys6UInt16V_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys6UInt32V_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7112,21 +7548,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys6UInt32V_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys6UInt64V_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7142,21 +7578,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys6UInt64V_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyyqd___0G0QztKSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : KeyedEncodingContainerProtocol, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7166,26 +7602,26 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyyqd___0G0QztKSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : KeyedEncodingContainerProtocol, τ_1_0 : Encodable>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeConditional",
           "printedName": "encodeConditional(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP17encodeConditional_6forKeyyqd___0H0QztKRld__CSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : KeyedEncodingContainerProtocol, T : AnyObject, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7195,26 +7631,26 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP17encodeConditional_6forKeyyqd___0H0QztKRld__CSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : KeyedEncodingContainerProtocol, τ_1_0 : AnyObject, τ_1_0 : Encodable>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySbSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7224,8 +7660,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Bool?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Bool>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7233,26 +7668,27 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySbSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySSSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7262,8 +7698,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "String?",
-              "usr": "s:Sq",
+              "printedName": "Optional<String>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7271,26 +7706,27 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySSSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySdSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7300,8 +7736,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Double>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7309,26 +7744,27 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySdSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySfSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7338,8 +7774,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Float>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7347,26 +7782,27 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySfSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySiSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7376,8 +7812,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7385,26 +7820,27 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySiSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys4Int8VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7414,8 +7850,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7423,26 +7858,27 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys4Int8VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys5Int16VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7452,8 +7888,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7461,26 +7896,27 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys5Int16VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys5Int32VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7490,8 +7926,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7499,26 +7934,27 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys5Int32VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys5Int64VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7528,8 +7964,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7537,26 +7972,27 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys5Int64VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySuSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7566,8 +8002,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7575,26 +8010,27 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySuSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys5UInt8VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7604,8 +8040,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7613,26 +8048,27 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys5UInt8VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys6UInt16VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7642,8 +8078,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7651,26 +8086,27 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys6UInt16VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys6UInt32VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7680,8 +8116,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7689,26 +8124,27 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys6UInt32VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys6UInt64VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7718,8 +8154,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7727,26 +8162,27 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys6UInt64VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyyqd__Sg_0I0QztKSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : KeyedEncodingContainerProtocol, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7756,76 +8192,77 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "T?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyyqd__Sg_0I0QztKSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : KeyedEncodingContainerProtocol, τ_1_0 : Encodable>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "nestedContainer",
           "printedName": "nestedContainer(keyedBy:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP06nestedC07keyedBy6forKeys0abC0Vyqd__Gqd__m_0I0Qzts06CodingI0Rd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, NestedKey where Self : KeyedEncodingContainerProtocol, NestedKey : CodingKey>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedEncodingContainer",
-              "printedName": "KeyedEncodingContainer<NestedKey>",
-              "usr": "s:s22KeyedEncodingContainerV",
+              "printedName": "KeyedEncodingContainer<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "NestedKey"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedEncodingContainerV"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "NestedKey.Type",
+              "printedName": "τ_1_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "NestedKey"
+                  "printedName": "τ_1_0"
                 }
               ]
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP06nestedC07keyedBy6forKeys0abC0Vyqd__Gqd__m_0I0Qzts06CodingI0Rd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : KeyedEncodingContainerProtocol, τ_1_0 : CodingKey>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "nestedUnkeyedContainer",
           "printedName": "nestedUnkeyedContainer(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP013nestedUnkeyedC06forKeys0fbC0_p0H0Qz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7836,20 +8273,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP013nestedUnkeyedC06forKeys0fbC0_p0H0Qz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "superEncoder",
           "printedName": "superEncoder()",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP12superEncoders0F0_pyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7857,18 +8294,18 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP12superEncoders0F0_pyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "superEncoder",
           "printedName": "superEncoder(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP12superEncoder6forKeys0F0_p0H0Qz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7879,24 +8316,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP12superEncoder6forKeys0F0_p0H0Qz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeConditional",
           "printedName": "encodeConditional(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE17encodeConditional_6forKeyyqd___0H0QztKRld__CSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : KeyedEncodingContainerProtocol, T : AnyObject, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -7906,29 +8339,25 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE17encodeConditional_6forKeyyqd___0H0QztKRld__CSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : KeyedEncodingContainerProtocol, τ_1_0 : AnyObject, τ_1_0 : Encodable>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySbSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -7938,8 +8367,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Bool?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Bool>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7947,29 +8375,26 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySbSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySSSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -7979,8 +8404,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "String?",
-              "usr": "s:Sq",
+              "printedName": "Optional<String>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7988,29 +8412,26 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySSSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySdSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8020,8 +8441,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Double>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8029,29 +8449,26 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySdSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySfSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8061,8 +8478,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Float>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8070,29 +8486,26 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySfSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySiSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8102,8 +8515,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8111,29 +8523,26 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySiSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys4Int8VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8143,8 +8552,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8152,29 +8560,26 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys4Int8VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys5Int16VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8184,8 +8589,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8193,29 +8597,26 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys5Int16VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys5Int32VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8225,8 +8626,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8234,29 +8634,26 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys5Int32VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys5Int64VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8266,8 +8663,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8275,29 +8671,26 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys5Int64VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySuSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8307,8 +8700,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8316,29 +8708,26 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySuSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys5UInt8VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8348,8 +8737,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8357,29 +8745,26 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys5UInt8VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys6UInt16VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8389,8 +8774,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8398,29 +8782,26 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys6UInt16VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys6UInt32VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8430,8 +8811,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8439,29 +8819,26 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys6UInt32VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys6UInt64VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8471,8 +8848,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8480,29 +8856,26 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys6UInt64VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyyqd__Sg_0I0QztKSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : KeyedEncodingContainerProtocol, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8512,108 +8885,78 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "T?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyyqd__Sg_0I0QztKSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : KeyedEncodingContainerProtocol, τ_1_0 : Encodable>",
+          "throwing": true,
+          "mutating": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s30KeyedEncodingContainerProtocolP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0.Key : CodingKey>"
     },
     {
       "kind": "TypeDecl",
       "name": "KeyedEncodingContainer",
       "printedName": "KeyedEncodingContainer",
-      "declKind": "Struct",
-      "usr": "s:s22KeyedEncodingContainerV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<K where K : CodingKey>",
-      "conformingProtocols": [
-        "KeyedEncodingContainerProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "Key",
-          "printedName": "Key",
-          "declKind": "TypeAlias",
-          "usr": "s:s22KeyedEncodingContainerV3Keya",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "K"
-            }
-          ]
-        },
-        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s22KeyedEncodingContainerVyAByxGqd__c3KeyQyd__Rszs0abC8ProtocolRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, Container where K == Container.Key, Container : KeyedEncodingContainerProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedEncodingContainer",
-              "printedName": "KeyedEncodingContainer<K>",
-              "usr": "s:s22KeyedEncodingContainerV",
+              "printedName": "KeyedEncodingContainer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "K"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedEncodingContainerV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Container"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s22KeyedEncodingContainerVyAByxGqd__c3KeyQyd__Rszs0abC8ProtocolRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Key, τ_1_0 : KeyedEncodingContainerProtocol>"
         },
         {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s22KeyedEncodingContainerV10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[CodingKey]",
-              "usr": "s:Sa",
+              "printedName": "Array<CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8621,23 +8964,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s22KeyedEncodingContainerV10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<K where K : CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<CodingKey>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -8645,26 +8983,24 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s22KeyedEncodingContainerV10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s22KeyedEncodingContainerV10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "encodeNil",
           "printedName": "encodeNil(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV9encodeNil6forKeyyx_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8672,33 +9008,22 @@
               "printedName": "()"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV9encodeNil6forKeyyx_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySb_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8712,33 +9037,22 @@
               "usr": "s:Sb"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySb_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySS_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8752,33 +9066,22 @@
               "usr": "s:SS"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySS_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySd_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8792,33 +9095,22 @@
               "usr": "s:Sd"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySd_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySf_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8832,33 +9124,22 @@
               "usr": "s:Sf"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySf_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySi_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8872,33 +9153,22 @@
               "usr": "s:Si"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySi_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys4Int8V_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8912,33 +9182,22 @@
               "usr": "s:s4Int8V"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys4Int8V_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys5Int16V_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8952,33 +9211,22 @@
               "usr": "s:s5Int16V"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys5Int16V_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys5Int32V_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8992,33 +9240,22 @@
               "usr": "s:s5Int32V"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys5Int32V_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys5Int64V_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9032,33 +9269,22 @@
               "usr": "s:s5Int64V"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys5Int64V_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySu_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9072,33 +9298,22 @@
               "usr": "s:Su"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySu_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys5UInt8V_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9112,33 +9327,22 @@
               "usr": "s:s5UInt8V"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys5UInt8V_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys6UInt16V_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9152,33 +9356,22 @@
               "usr": "s:s6UInt16V"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys6UInt16V_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys6UInt32V_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9192,33 +9385,22 @@
               "usr": "s:s6UInt32V"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys6UInt32V_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys6UInt64V_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9232,33 +9414,22 @@
               "usr": "s:s6UInt64V"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys6UInt64V_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyyqd___xtKSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, T where K : CodingKey, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9268,36 +9439,25 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyyqd___xtKSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : CodingKey, τ_1_0 : Encodable>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeConditional",
           "printedName": "encodeConditional(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV17encodeConditional_6forKeyyqd___xtKRld__CSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, T where K : CodingKey, T : AnyObject, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9307,36 +9467,25 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV17encodeConditional_6forKeyyqd___xtKRld__CSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : CodingKey, τ_1_0 : AnyObject, τ_1_0 : Encodable>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySbSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9346,8 +9495,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Bool?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Bool>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9355,36 +9503,26 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySbSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySSSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9394,8 +9532,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "String?",
-              "usr": "s:Sq",
+              "printedName": "Optional<String>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9403,36 +9540,26 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySSSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySdSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9442,8 +9569,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Double>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9451,36 +9577,26 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySdSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySfSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9490,8 +9606,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Float>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9499,36 +9614,26 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySfSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySiSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9538,8 +9643,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9547,36 +9651,26 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySiSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys4Int8VSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9586,8 +9680,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9595,36 +9688,26 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys4Int8VSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys5Int16VSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9634,8 +9717,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9643,36 +9725,26 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys5Int16VSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys5Int32VSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9682,8 +9754,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9691,36 +9762,26 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys5Int32VSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys5Int64VSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9730,8 +9791,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9739,36 +9799,26 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys5Int64VSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySuSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9778,8 +9828,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9787,36 +9836,26 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySuSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys5UInt8VSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9826,8 +9865,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9835,36 +9873,26 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys5UInt8VSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys6UInt16VSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9874,8 +9902,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9883,36 +9910,26 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys6UInt16VSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys6UInt32VSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9922,8 +9939,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9931,36 +9947,26 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys6UInt32VSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys6UInt64VSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9970,8 +9976,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9979,36 +9984,26 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys6UInt64VSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyyqd__Sg_xtKSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, T where K : CodingKey, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -10018,96 +10013,75 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "T?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyyqd__Sg_xtKSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : CodingKey, τ_1_0 : Encodable>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "nestedContainer",
           "printedName": "nestedContainer(keyedBy:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV06nestedC07keyedBy6forKeyAByqd__Gqd__m_xts06CodingH0Rd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, NestedKey where K : CodingKey, NestedKey : CodingKey>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedEncodingContainer",
-              "printedName": "KeyedEncodingContainer<NestedKey>",
-              "usr": "s:s22KeyedEncodingContainerV",
+              "printedName": "KeyedEncodingContainer<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "NestedKey"
+                  "printedName": "τ_1_0"
+                }
+              ],
+              "usr": "s:s22KeyedEncodingContainerV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_1_0.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
                 }
               ]
             },
             {
               "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "NestedKey.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "NestedKey"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV06nestedC07keyedBy6forKeyAByqd__Gqd__m_xts06CodingH0Rd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : CodingKey, τ_1_0 : CodingKey>",
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "nestedUnkeyedContainer",
           "printedName": "nestedUnkeyedContainer(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV013nestedUnkeyedC06forKeys0ebC0_px_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -10116,32 +10090,21 @@
               "usr": "s:s24UnkeyedEncodingContainerP"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV013nestedUnkeyedC06forKeys0ebC0_px_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "superEncoder",
           "printedName": "superEncoder()",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV12superEncoders0E0_pyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -10149,21 +10112,17 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV12superEncoders0E0_pyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "superEncoder",
           "printedName": "superEncoder(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV12superEncoder6forKeys0E0_px_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -10172,45 +10131,49 @@
               "usr": "s:s7EncoderP"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedEncodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV12superEncoder6forKeys0E0_px_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "mutating": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s22KeyedEncodingContainerV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+      "conformingProtocols": [
+        "KeyedEncodingContainerProtocol"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "KeyedDecodingContainerProtocol",
       "printedName": "KeyedDecodingContainerProtocol",
-      "declKind": "Protocol",
-      "usr": "s:s30KeyedDecodingContainerProtocolP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self.Key : CodingKey>",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Key",
+          "printedName": "Key",
+          "declKind": "AssociatedType",
+          "usr": "s:s30KeyedDecodingContainerProtocolP3KeyQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s30KeyedDecodingContainerProtocolP10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[CodingKey]",
-              "usr": "s:Sa",
+              "printedName": "Array<CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -10218,23 +10181,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s30KeyedDecodingContainerProtocolP10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<CodingKey>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -10242,70 +10200,73 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s30KeyedDecodingContainerProtocolP10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s30KeyedDecodingContainerProtocolP10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "allKeys",
           "printedName": "allKeys",
-          "declKind": "Var",
-          "usr": "s:s30KeyedDecodingContainerProtocolP7allKeysSay3KeyQzGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Self.Key]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0.Key>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Key"
+                  "printedName": "τ_0_0.Key"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s30KeyedDecodingContainerProtocolP7allKeysSay3KeyQzGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[Self.Key]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<τ_0_0.Key>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Key"
+                      "printedName": "τ_0_0.Key"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s30KeyedDecodingContainerProtocolP7allKeysSay3KeyQzGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s30KeyedDecodingContainerProtocolP7allKeysSay3KeyQzGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP8containsySb3KeyQzF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -10316,20 +10277,19 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP8containsySb3KeyQzF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "decodeNil",
           "printedName": "decodeNil(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP9decodeNil6forKeySb0H0Qz_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10340,20 +10300,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP9decodeNil6forKeySb0H0Qz_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2bm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10377,20 +10337,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2bm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2Sm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10414,20 +10374,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2Sm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2dm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10451,20 +10411,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2dm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2fm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10488,20 +10448,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2fm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2im_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10525,20 +10485,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2im_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys4Int8VAFm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10562,20 +10522,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys4Int8VAFm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys5Int16VAFm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10599,20 +10559,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys5Int16VAFm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys5Int32VAFm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10636,20 +10596,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys5Int32VAFm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys5Int64VAFm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10673,20 +10633,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys5Int64VAFm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2um_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10710,20 +10670,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2um_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys5UInt8VAFm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10747,20 +10707,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys5UInt8VAFm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys6UInt16VAFm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10784,20 +10744,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys6UInt16VAFm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys6UInt32VAFm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10821,20 +10781,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys6UInt32VAFm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys6UInt64VAFm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10858,61 +10818,60 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys6UInt64VAFm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyqd__qd__m_0G0QztKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : KeyedDecodingContainerProtocol, T : Decodable>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_1_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
               ]
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyqd__qd__m_0G0QztKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : KeyedDecodingContainerProtocol, τ_1_0 : Decodable>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySbSgSbm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Bool?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Bool>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -10920,7 +10879,8 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -10938,26 +10898,25 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySbSgSbm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySSSgSSm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "String?",
-              "usr": "s:Sq",
+              "printedName": "Optional<String>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -10965,7 +10924,8 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -10983,26 +10943,25 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySSSgSSm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySdSgSdm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Double>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11010,7 +10969,8 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11028,26 +10988,25 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySdSgSdm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySfSgSfm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Float>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11055,7 +11014,8 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11073,26 +11033,25 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySfSgSfm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySiSgSim_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11100,7 +11059,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11118,26 +11078,25 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySiSgSim_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys4Int8VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11145,7 +11104,8 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11163,26 +11123,25 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys4Int8VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys5Int16VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11190,7 +11149,8 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11208,26 +11168,25 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys5Int16VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys5Int32VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11235,7 +11194,8 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11253,26 +11213,25 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys5Int32VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys5Int64VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11280,7 +11239,8 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11298,26 +11258,25 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys5Int64VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySuSgSum_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11325,7 +11284,8 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11343,26 +11303,25 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySuSgSum_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys5UInt8VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11370,7 +11329,8 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11388,26 +11348,25 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys5UInt8VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys6UInt16VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11415,7 +11374,8 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11433,26 +11393,25 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys6UInt16VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys6UInt32VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11460,7 +11419,8 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11478,26 +11438,25 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys6UInt32VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys6UInt64VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11505,7 +11464,8 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11523,106 +11483,106 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys6UInt64VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeyqd__Sgqd__m_0I0QztKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : KeyedDecodingContainerProtocol, T : Decodable>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "T?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_1_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
               ]
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeyqd__Sgqd__m_0I0QztKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : KeyedDecodingContainerProtocol, τ_1_0 : Decodable>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "nestedContainer",
           "printedName": "nestedContainer(keyedBy:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP06nestedC07keyedBy6forKeys0abC0Vyqd__Gqd__m_0I0QztKs06CodingI0Rd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, NestedKey where Self : KeyedDecodingContainerProtocol, NestedKey : CodingKey>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedDecodingContainer",
-              "printedName": "KeyedDecodingContainer<NestedKey>",
-              "usr": "s:s22KeyedDecodingContainerV",
+              "printedName": "KeyedDecodingContainer<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "NestedKey"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedDecodingContainerV"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "NestedKey.Type",
+              "printedName": "τ_1_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "NestedKey"
+                  "printedName": "τ_1_0"
                 }
               ]
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP06nestedC07keyedBy6forKeys0abC0Vyqd__Gqd__m_0I0QztKs06CodingI0Rd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : KeyedDecodingContainerProtocol, τ_1_0 : CodingKey>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "nestedUnkeyedContainer",
           "printedName": "nestedUnkeyedContainer(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP013nestedUnkeyedC06forKeys0fbC0_p0H0Qz_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -11633,20 +11593,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP013nestedUnkeyedC06forKeys0fbC0_p0H0Qz_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "superDecoder",
           "printedName": "superDecoder()",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP12superDecoders0F0_pyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -11654,18 +11614,18 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP12superDecoders0F0_pyKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "superDecoder",
           "printedName": "superDecoder(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP12superDecoder6forKeys0F0_p0H0Qz_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -11676,29 +11636,25 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP12superDecoder6forKeys0F0_p0H0Qz_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySbSgSbm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Bool?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Bool>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11706,7 +11662,8 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11724,29 +11681,24 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySbSgSbm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySSSgSSm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "String?",
-              "usr": "s:Sq",
+              "printedName": "Optional<String>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11754,7 +11706,8 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11772,29 +11725,24 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySSSgSSm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySdSgSdm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Double>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11802,7 +11750,8 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11820,29 +11769,24 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySdSgSdm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySfSgSfm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Float>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11850,7 +11794,8 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11868,29 +11813,24 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySfSgSfm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySiSgSim_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11898,7 +11838,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11916,29 +11857,24 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySiSgSim_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys4Int8VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11946,7 +11882,8 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11964,29 +11901,24 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys4Int8VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys5Int16VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11994,7 +11926,8 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -12012,29 +11945,24 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys5Int16VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys5Int32VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -12042,7 +11970,8 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -12060,29 +11989,24 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys5Int32VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys5Int64VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -12090,7 +12014,8 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -12108,29 +12033,24 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys5Int64VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySuSgSum_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -12138,7 +12058,8 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -12156,29 +12077,24 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySuSgSum_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys5UInt8VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -12186,7 +12102,8 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -12204,29 +12121,24 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys5UInt8VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys6UInt16VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -12234,7 +12146,8 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -12252,29 +12165,24 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys6UInt16VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys6UInt32VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -12282,7 +12190,8 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -12300,29 +12209,24 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys6UInt32VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys6UInt64VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -12330,7 +12234,8 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -12348,141 +12253,106 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys6UInt64VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeyqd__Sgqd__m_0I0QztKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : KeyedDecodingContainerProtocol, T : Decodable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "T?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_1_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
               ]
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Key"
+              "printedName": "τ_0_0.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeyqd__Sgqd__m_0I0QztKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : KeyedDecodingContainerProtocol, τ_1_0 : Decodable>",
+          "throwing": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s30KeyedDecodingContainerProtocolP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0.Key : CodingKey>"
     },
     {
       "kind": "TypeDecl",
       "name": "KeyedDecodingContainer",
       "printedName": "KeyedDecodingContainer",
-      "declKind": "Struct",
-      "usr": "s:s22KeyedDecodingContainerV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<K where K : CodingKey>",
-      "conformingProtocols": [
-        "KeyedDecodingContainerProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "Key",
-          "printedName": "Key",
-          "declKind": "TypeAlias",
-          "usr": "s:s22KeyedDecodingContainerV3Keya",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "K"
-            }
-          ]
-        },
-        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s22KeyedDecodingContainerVyAByxGqd__c3KeyQyd__Rszs0abC8ProtocolRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, Container where K == Container.Key, Container : KeyedDecodingContainerProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedDecodingContainer",
-              "printedName": "KeyedDecodingContainer<K>",
-              "usr": "s:s22KeyedDecodingContainerV",
+              "printedName": "KeyedDecodingContainer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "K"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedDecodingContainerV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Container"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s22KeyedDecodingContainerVyAByxGqd__c3KeyQyd__Rszs0abC8ProtocolRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Key, τ_1_0 : KeyedDecodingContainerProtocol>"
         },
         {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s22KeyedDecodingContainerV10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[CodingKey]",
-              "usr": "s:Sa",
+              "printedName": "Array<CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -12490,23 +12360,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s22KeyedDecodingContainerV10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<K where K : CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<CodingKey>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -12514,76 +12379,71 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s22KeyedDecodingContainerV10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s22KeyedDecodingContainerV10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "allKeys",
           "printedName": "allKeys",
-          "declKind": "Var",
-          "usr": "s:s22KeyedDecodingContainerV7allKeysSayxGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[K]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "K"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s22KeyedDecodingContainerV7allKeysSayxGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<K where K : CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[K]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "K"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s22KeyedDecodingContainerV7allKeysSayxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s22KeyedDecodingContainerV7allKeysSayxGvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV8containsySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12592,32 +12452,20 @@
               "usr": "s:Sb"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV8containsySbxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>"
         },
         {
           "kind": "Function",
           "name": "decodeNil",
           "printedName": "decodeNil(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV9decodeNil6forKeySbx_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12626,32 +12474,21 @@
               "usr": "s:Sb"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV9decodeNil6forKeySbx_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2bm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12673,32 +12510,21 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2bm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2Sm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12720,32 +12546,21 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2Sm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2dm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12767,32 +12582,21 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2dm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2fm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12814,32 +12618,21 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2fm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2im_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12861,32 +12654,21 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2im_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys4Int8VAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12908,32 +12690,21 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys4Int8VAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys5Int16VAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12955,32 +12726,21 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys5Int16VAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys5Int32VAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -13002,32 +12762,21 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys5Int32VAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys5Int64VAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -13049,32 +12798,21 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys5Int64VAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2um_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -13096,32 +12834,21 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2um_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys5UInt8VAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -13143,32 +12870,21 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys5UInt8VAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys6UInt16VAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -13190,32 +12906,21 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys6UInt16VAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys6UInt32VAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -13237,32 +12942,21 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys6UInt32VAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys6UInt64VAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -13284,83 +12978,60 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys6UInt64VAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyqd__qd__m_xtKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, T where K : CodingKey, T : Decodable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_1_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyqd__qd__m_xtKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : CodingKey, τ_1_0 : Decodable>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySbSgSbm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Bool?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Bool>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13368,7 +13039,8 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13384,38 +13056,26 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySbSgSbm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySSSgSSm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "String?",
-              "usr": "s:Sq",
+              "printedName": "Optional<String>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13423,7 +13083,8 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13439,38 +13100,26 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySSSgSSm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySdSgSdm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Double>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13478,7 +13127,8 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13494,38 +13144,26 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySdSgSdm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySfSgSfm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Float>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13533,7 +13171,8 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13549,38 +13188,26 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySfSgSfm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySiSgSim_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13588,7 +13215,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13604,38 +13232,26 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySiSgSim_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys4Int8VSgAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13643,7 +13259,8 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13659,38 +13276,26 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys4Int8VSgAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys5Int16VSgAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13698,7 +13303,8 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13714,38 +13320,26 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys5Int16VSgAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys5Int32VSgAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13753,7 +13347,8 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13769,38 +13364,26 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys5Int32VSgAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys5Int64VSgAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13808,7 +13391,8 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13824,38 +13408,26 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys5Int64VSgAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySuSgSum_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13863,7 +13435,8 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13879,38 +13452,26 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySuSgSum_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys5UInt8VSgAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13918,7 +13479,8 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13934,38 +13496,26 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys5UInt8VSgAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys6UInt16VSgAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13973,7 +13523,8 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13989,38 +13540,26 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys6UInt16VSgAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys6UInt32VSgAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -14028,7 +13567,8 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -14044,38 +13584,26 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys6UInt32VSgAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys6UInt64VSgAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -14083,7 +13611,8 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -14099,138 +13628,105 @@
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys6UInt64VSgAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeyqd__Sgqd__m_xtKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, T where K : CodingKey, T : Decodable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "T?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_1_0.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
                 }
               ]
             },
             {
               "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "T.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeyqd__Sgqd__m_xtKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : CodingKey, τ_1_0 : Decodable>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "nestedContainer",
           "printedName": "nestedContainer(keyedBy:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV06nestedC07keyedBy6forKeyAByqd__Gqd__m_xtKs06CodingH0Rd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, NestedKey where K : CodingKey, NestedKey : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedDecodingContainer",
-              "printedName": "KeyedDecodingContainer<NestedKey>",
-              "usr": "s:s22KeyedDecodingContainerV",
+              "printedName": "KeyedDecodingContainer<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "NestedKey"
+                  "printedName": "τ_1_0"
+                }
+              ],
+              "usr": "s:s22KeyedDecodingContainerV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_1_0.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
                 }
               ]
             },
             {
               "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "NestedKey.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "NestedKey"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV06nestedC07keyedBy6forKeyAByqd__Gqd__m_xtKs06CodingH0Rd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : CodingKey, τ_1_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "nestedUnkeyedContainer",
           "printedName": "nestedUnkeyedContainer(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV013nestedUnkeyedC06forKeys0ebC0_px_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -14239,32 +13735,21 @@
               "usr": "s:s24UnkeyedDecodingContainerP"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV013nestedUnkeyedC06forKeys0ebC0_px_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "superDecoder",
           "printedName": "superDecoder()",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV12superDecoders0E0_pyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -14272,21 +13757,17 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV12superDecoders0E0_pyKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "superDecoder",
           "printedName": "superDecoder(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV12superDecoder6forKeys0E0_px_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -14295,44 +13776,40 @@
               "usr": "s:s7DecoderP"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "KeyedDecodingContainer<K>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV12superDecoder6forKeys0E0_px_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+          "throwing": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s22KeyedDecodingContainerV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : CodingKey>",
+      "conformingProtocols": [
+        "KeyedDecodingContainerProtocol"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnkeyedEncodingContainer",
       "printedName": "UnkeyedEncodingContainer",
-      "declKind": "Protocol",
-      "usr": "s:s24UnkeyedEncodingContainerP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s24UnkeyedEncodingContainerP10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[CodingKey]",
-              "usr": "s:Sa",
+              "printedName": "Array<CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -14340,23 +13817,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s24UnkeyedEncodingContainerP10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<CodingKey>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -14364,20 +13836,25 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s24UnkeyedEncodingContainerP10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s24UnkeyedEncodingContainerP10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s24UnkeyedEncodingContainerP5countSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14389,11 +13866,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s24UnkeyedEncodingContainerP5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -14401,40 +13873,41 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s24UnkeyedEncodingContainerP5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s24UnkeyedEncodingContainerP5countSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "encodeNil",
           "printedName": "encodeNil()",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP9encodeNilyyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP9encodeNilyyKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySbKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14447,19 +13920,19 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySbKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySSKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14472,19 +13945,19 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySSKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySdKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14497,19 +13970,19 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySdKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySfKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14522,19 +13995,19 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySfKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySiKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14547,19 +14020,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySiKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys4Int8VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14572,19 +14045,19 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys4Int8VKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys5Int16VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14597,19 +14070,19 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys5Int16VKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys5Int32VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14622,19 +14095,19 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys5Int32VKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys5Int64VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14647,19 +14120,19 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys5Int64VKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySuKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14672,19 +14145,19 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySuKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys5UInt8VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14697,19 +14170,19 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys5UInt8VKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys6UInt16VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14722,19 +14195,19 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys6UInt16VKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys6UInt32VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14747,19 +14220,19 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys6UInt32VKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys6UInt64VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14772,19 +14245,19 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys6UInt64VKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyyqd__KSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14794,21 +14267,45 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyyqd__KSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Encodable>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeConditional",
           "printedName": "encodeConditional(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP17encodeConditionalyyqd__KRld__CSERd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : AnyObject, T : Encodable>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : AnyObject, τ_1_0 : Encodable>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14818,21 +14315,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__Sb7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Bool>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == Bool>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14842,21 +14339,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__SS7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == String>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == String>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14866,21 +14363,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__Sd7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Double>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == Double>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14890,21 +14387,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__Sf7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Float>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == Float>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14914,21 +14411,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__Si7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == Int>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14938,21 +14435,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__s4Int8V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int8>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == Int8>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14962,21 +14459,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__s5Int16V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int16>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == Int16>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14986,21 +14483,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__s5Int32V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int32>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == Int32>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15010,21 +14507,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__s5Int64V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int64>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == Int64>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15034,21 +14531,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__Su7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == UInt>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15058,21 +14555,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__s5UInt8V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt8>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == UInt8>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15082,21 +14579,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__s6UInt16V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt16>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == UInt16>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15106,21 +14603,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__s6UInt32V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt32>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == UInt32>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15130,45 +14627,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__s6UInt64V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt64>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == UInt64>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__SE7ElementRpd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element : Encodable>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -15178,58 +14651,59 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__SE7ElementRpd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element : Encodable>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "nestedContainer",
           "printedName": "nestedContainer(keyedBy:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP06nestedC07keyedBys05KeyedbC0Vyqd__Gqd__m_ts9CodingKeyRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, NestedKey where Self : UnkeyedEncodingContainer, NestedKey : CodingKey>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedEncodingContainer",
-              "printedName": "KeyedEncodingContainer<NestedKey>",
-              "usr": "s:s22KeyedEncodingContainerV",
+              "printedName": "KeyedEncodingContainer<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "NestedKey"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedEncodingContainerV"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "NestedKey.Type",
+              "printedName": "τ_1_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "NestedKey"
+                  "printedName": "τ_1_0"
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP06nestedC07keyedBys05KeyedbC0Vyqd__Gqd__m_ts9CodingKeyRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : CodingKey>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "nestedUnkeyedContainer",
           "printedName": "nestedUnkeyedContainer()",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP06nestedaC0sAA_pyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -15237,18 +14711,18 @@
               "printedName": "UnkeyedEncodingContainer",
               "usr": "s:s24UnkeyedEncodingContainerP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP06nestedaC0sAA_pyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "superEncoder",
           "printedName": "superEncoder()",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP12superEncoders0E0_pyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -15256,22 +14730,41 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP12superEncoders0E0_pyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeConditional",
           "printedName": "encodeConditional(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE17encodeConditionalyyqd__KRld__CSERd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : AnyObject, T : Encodable>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : AnyObject, τ_1_0 : Encodable>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15281,24 +14774,20 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__Sb7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Bool>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == Bool>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15308,24 +14797,20 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__SS7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == String>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == String>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15335,24 +14820,20 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__Sd7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Double>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == Double>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15362,24 +14843,20 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__Sf7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Float>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == Float>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15389,24 +14866,20 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__Si7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == Int>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15416,24 +14889,20 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__s4Int8V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int8>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == Int8>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15443,24 +14912,20 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__s5Int16V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int16>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == Int16>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15470,24 +14935,20 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__s5Int32V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int32>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == Int32>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15497,24 +14958,20 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__s5Int64V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int64>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == Int64>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15524,24 +14981,20 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__Su7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == UInt>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15551,24 +15004,20 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__s5UInt8V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt8>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == UInt8>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15578,24 +15027,20 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__s6UInt16V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt16>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == UInt16>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15605,24 +15050,20 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__s6UInt32V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt32>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == UInt32>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15632,51 +15073,20 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__s6UInt64V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt64>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element == UInt64>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__SE7ElementRpd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element : Encodable>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -15686,35 +15096,35 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__SE7ElementRpd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedEncodingContainer, τ_1_0 : Sequence, τ_1_0.Element : Encodable>",
+          "throwing": true,
+          "mutating": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s24UnkeyedEncodingContainerP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "UnkeyedDecodingContainer",
       "printedName": "UnkeyedDecodingContainer",
-      "declKind": "Protocol",
-      "usr": "s:s24UnkeyedDecodingContainerP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s24UnkeyedDecodingContainerP10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[CodingKey]",
-              "usr": "s:Sa",
+              "printedName": "Array<CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -15722,23 +15132,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s24UnkeyedDecodingContainerP10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<CodingKey>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -15746,26 +15151,30 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s24UnkeyedDecodingContainerP10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s24UnkeyedDecodingContainerP10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s24UnkeyedDecodingContainerP5countSiSgvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -15773,23 +15182,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s24UnkeyedDecodingContainerP5countSiSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Int?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<Int>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -15797,20 +15201,25 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s24UnkeyedDecodingContainerP5countSiSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s24UnkeyedDecodingContainerP5countSiSgvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "isAtEnd",
           "printedName": "isAtEnd",
-          "declKind": "Var",
-          "usr": "s:s24UnkeyedDecodingContainerP7isAtEndSbvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15822,11 +15231,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s24UnkeyedDecodingContainerP7isAtEndSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -15834,18 +15238,22 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s24UnkeyedDecodingContainerP7isAtEndSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s24UnkeyedDecodingContainerP7isAtEndSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "currentIndex",
           "printedName": "currentIndex",
-          "declKind": "Var",
-          "usr": "s:s24UnkeyedDecodingContainerP12currentIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15857,11 +15265,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s24UnkeyedDecodingContainerP12currentIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -15869,21 +15272,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s24UnkeyedDecodingContainerP12currentIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s24UnkeyedDecodingContainerP12currentIndexSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "decodeNil",
           "printedName": "decodeNil()",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP9decodeNilSbyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -15891,19 +15295,19 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP9decodeNilSbyKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2bmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -15924,19 +15328,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2bmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2SmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -15957,19 +15361,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2SmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2dmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -15990,19 +15394,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2dmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2fmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16023,19 +15427,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2fmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2imKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16056,19 +15460,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2imKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeys4Int8VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16089,19 +15493,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeys4Int8VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeys5Int16VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16122,19 +15526,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeys5Int16VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeys5Int32VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16155,19 +15559,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeys5Int32VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeys5Int64VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16188,19 +15592,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeys5Int64VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2umKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16221,19 +15625,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2umKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeys5UInt8VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16254,19 +15658,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeys5UInt8VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeys6UInt16VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16287,19 +15691,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeys6UInt16VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeys6UInt32VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16320,19 +15724,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeys6UInt32VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeys6UInt64VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16353,56 +15757,55 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeys6UInt64VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeyqd__qd__mKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedDecodingContainer, T : Decodable>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_1_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeyqd__qd__mKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedDecodingContainer, τ_1_0 : Decodable>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySbSgSbmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Bool?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Bool>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16410,7 +15813,8 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16425,25 +15829,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySbSgSbmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySSSgSSmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "String?",
-              "usr": "s:Sq",
+              "printedName": "Optional<String>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16451,7 +15854,8 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16466,25 +15870,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySSSgSSmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySdSgSdmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Double>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16492,7 +15895,8 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16507,25 +15911,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySdSgSdmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySfSgSfmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Float>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16533,7 +15936,8 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16548,25 +15952,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySfSgSfmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySiSgSimKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16574,7 +15977,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16589,25 +15993,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySiSgSimKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys4Int8VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16615,7 +16018,8 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16630,25 +16034,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys4Int8VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys5Int16VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16656,7 +16059,8 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16671,25 +16075,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys5Int16VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys5Int32VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16697,7 +16100,8 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16712,25 +16116,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys5Int32VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys5Int64VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16738,7 +16141,8 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16753,25 +16157,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys5Int64VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySuSgSumKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16779,7 +16182,8 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16794,25 +16198,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySuSgSumKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys5UInt8VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16820,7 +16223,8 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16835,25 +16239,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys5UInt8VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys6UInt16VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16861,7 +16264,8 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16876,25 +16280,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys6UInt16VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys6UInt32VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16902,7 +16305,8 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16917,25 +16321,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys6UInt32VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys6UInt64VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16943,7 +16346,8 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16958,97 +16362,97 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys6UInt64VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentyqd__Sgqd__mKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedDecodingContainer, T : Decodable>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "T?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_1_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentyqd__Sgqd__mKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedDecodingContainer, τ_1_0 : Decodable>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "nestedContainer",
           "printedName": "nestedContainer(keyedBy:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP06nestedC07keyedBys05KeyedbC0Vyqd__Gqd__m_tKs9CodingKeyRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, NestedKey where Self : UnkeyedDecodingContainer, NestedKey : CodingKey>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedDecodingContainer",
-              "printedName": "KeyedDecodingContainer<NestedKey>",
-              "usr": "s:s22KeyedDecodingContainerV",
+              "printedName": "KeyedDecodingContainer<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "NestedKey"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedDecodingContainerV"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "NestedKey.Type",
+              "printedName": "τ_1_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "NestedKey"
+                  "printedName": "τ_1_0"
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP06nestedC07keyedBys05KeyedbC0Vyqd__Gqd__m_tKs9CodingKeyRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedDecodingContainer, τ_1_0 : CodingKey>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "nestedUnkeyedContainer",
           "printedName": "nestedUnkeyedContainer()",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP06nestedaC0sAA_pyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17056,19 +16460,19 @@
               "printedName": "UnkeyedDecodingContainer",
               "usr": "s:s24UnkeyedDecodingContainerP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP06nestedaC0sAA_pyKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "superDecoder",
           "printedName": "superDecoder()",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP12superDecoders0E0_pyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17076,28 +16480,24 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP12superDecoders0E0_pyKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySbSgSbmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Bool?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Bool>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17105,7 +16505,8 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17120,28 +16521,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySbSgSbmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySSSgSSmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "String?",
-              "usr": "s:Sq",
+              "printedName": "Optional<String>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17149,7 +16545,8 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17164,28 +16561,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySSSgSSmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySdSgSdmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Double>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17193,7 +16585,8 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17208,28 +16601,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySdSgSdmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySfSgSfmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Float>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17237,7 +16625,8 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17252,28 +16641,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySfSgSfmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySiSgSimKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17281,7 +16665,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17296,28 +16681,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySiSgSimKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys4Int8VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17325,7 +16705,8 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17340,28 +16721,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys4Int8VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys5Int16VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17369,7 +16745,8 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17384,28 +16761,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys5Int16VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys5Int32VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17413,7 +16785,8 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17428,28 +16801,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys5Int32VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys5Int64VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17457,7 +16825,8 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17472,28 +16841,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys5Int64VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySuSgSumKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17501,7 +16865,8 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17516,28 +16881,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySuSgSumKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys5UInt8VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17545,7 +16905,8 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17560,28 +16921,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys5UInt8VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys6UInt16VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17589,7 +16945,8 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17604,28 +16961,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys6UInt16VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys6UInt32VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17633,7 +16985,8 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17648,28 +17001,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys6UInt32VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys6UInt64VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17677,7 +17025,8 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17692,75 +17041,71 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys6UInt64VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentyqd__Sgqd__mKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedDecodingContainer, T : Decodable>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "T?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_1_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentyqd__Sgqd__mKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnkeyedDecodingContainer, τ_1_0 : Decodable>",
+          "throwing": true,
+          "mutating": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s24UnkeyedDecodingContainerP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "SingleValueEncodingContainer",
       "printedName": "SingleValueEncodingContainer",
-      "declKind": "Protocol",
-      "usr": "s:s28SingleValueEncodingContainerP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s28SingleValueEncodingContainerP10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[CodingKey]",
-              "usr": "s:Sa",
+              "printedName": "Array<CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17768,23 +17113,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s28SingleValueEncodingContainerP10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : SingleValueEncodingContainer>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<CodingKey>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -17792,42 +17132,44 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s28SingleValueEncodingContainerP10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : SingleValueEncodingContainer>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s28SingleValueEncodingContainerP10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "encodeNil",
           "printedName": "encodeNil()",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP9encodeNilyyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP9encodeNilyyKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyySbKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17840,19 +17182,19 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyySbKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyySSKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17865,19 +17207,19 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyySSKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyySdKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17890,19 +17232,19 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyySdKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyySfKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17915,19 +17257,19 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyySfKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyySiKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17940,19 +17282,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyySiKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyys4Int8VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17965,19 +17307,19 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyys4Int8VKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyys5Int16VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17990,19 +17332,19 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyys5Int16VKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyys5Int32VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18015,19 +17357,19 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyys5Int32VKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyys5Int64VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18040,19 +17382,19 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyys5Int64VKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyySuKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18065,19 +17407,19 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyySuKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyys5UInt8VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18090,19 +17432,19 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyys5UInt8VKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyys6UInt16VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18115,19 +17457,19 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyys6UInt16VKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyys6UInt32VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18140,19 +17482,19 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyys6UInt32VKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyys6UInt64VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18165,19 +17507,19 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyys6UInt64VKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyyqd__KSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : SingleValueEncodingContainer, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18187,35 +17529,36 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyyqd__KSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : SingleValueEncodingContainer, τ_1_0 : Encodable>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s28SingleValueEncodingContainerP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "SingleValueDecodingContainer",
       "printedName": "SingleValueDecodingContainer",
-      "declKind": "Protocol",
-      "usr": "s:s28SingleValueDecodingContainerP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s28SingleValueDecodingContainerP10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[CodingKey]",
-              "usr": "s:Sa",
+              "printedName": "Array<CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -18223,23 +17566,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s28SingleValueDecodingContainerP10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : SingleValueDecodingContainer>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<CodingKey>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -18247,21 +17585,25 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s28SingleValueDecodingContainerP10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : SingleValueDecodingContainer>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s28SingleValueDecodingContainerP10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "decodeNil",
           "printedName": "decodeNil()",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP9decodeNilSbyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -18269,18 +17611,17 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP9decodeNilSbyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueDecodingContainer>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2bmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18301,18 +17642,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2bmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2SmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18333,18 +17674,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2SmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2dmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18365,18 +17706,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2dmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2fmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18397,18 +17738,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2fmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2imKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18429,18 +17770,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2imKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeys4Int8VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18461,18 +17802,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeys4Int8VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeys5Int16VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18493,18 +17834,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeys5Int16VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeys5Int32VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18525,18 +17866,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeys5Int32VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeys5Int64VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18557,18 +17898,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeys5Int64VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2umKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18589,18 +17930,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2umKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeys5UInt8VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18621,18 +17962,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeys5UInt8VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeys6UInt16VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18653,18 +17994,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeys6UInt16VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeys6UInt32VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18685,18 +18026,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeys6UInt32VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeys6UInt64VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18717,82 +18058,58 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeys6UInt64VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeyqd__qd__mKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : SingleValueDecodingContainer, T : Decodable>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_1_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeyqd__qd__mKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : SingleValueDecodingContainer, τ_1_0 : Decodable>",
+          "protocolReq": true,
+          "throwing": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s28SingleValueDecodingContainerP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "CodingUserInfoKey",
       "printedName": "CodingUserInfoKey",
-      "declKind": "Struct",
-      "usr": "s:s17CodingUserInfoKeyV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "RawRepresentable",
-        "Equatable",
-        "Hashable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "RawValue",
-          "printedName": "RawValue",
-          "declKind": "TypeAlias",
-          "usr": "s:s17CodingUserInfoKeyV8RawValuea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
           "kind": "Var",
           "name": "rawValue",
           "printedName": "rawValue",
-          "declKind": "Var",
-          "usr": "s:s17CodingUserInfoKeyV8rawValueSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -18804,13 +18121,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17CodingUserInfoKeyV8rawValueSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -18818,27 +18128,28 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17CodingUserInfoKeyV8rawValueSSvg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17CodingUserInfoKeyV8rawValueSSvp",
+          "moduleName": "Swift",
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(rawValue:)",
-          "declKind": "Constructor",
-          "usr": "s:s17CodingUserInfoKeyV8rawValueABSgSS_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "CodingUserInfoKey?",
-              "usr": "s:Sq",
+              "printedName": "Optional<CodingUserInfoKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -18846,7 +18157,8 @@
                   "printedName": "CodingUserInfoKey",
                   "usr": "s:s17CodingUserInfoKeyV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -18854,19 +18166,44 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17CodingUserInfoKeyV8rawValueABSgSS_tcfc",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "CodingUserInfoKey",
+              "printedName": "CodingUserInfoKey",
+              "usr": "s:s17CodingUserInfoKeyV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "CodingUserInfoKey",
+              "printedName": "CodingUserInfoKey",
+              "usr": "s:s17CodingUserInfoKeyV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17CodingUserInfoKeyV2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s17CodingUserInfoKeyV9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -18878,10 +18215,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17CodingUserInfoKeyV9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -18889,21 +18222,20 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17CodingUserInfoKeyV9hashValueSivg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17CodingUserInfoKeyV9hashValueSivp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s17CodingUserInfoKeyV4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -18916,45 +18248,40 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s17CodingUserInfoKeyV4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s17CodingUserInfoKeyV",
+      "moduleName": "Swift",
+      "conformingProtocols": [
+        "RawRepresentable",
+        "Equatable",
+        "Hashable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "EncodingError",
       "printedName": "EncodingError",
-      "declKind": "Enum",
-      "usr": "s:s13EncodingErrorO",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Error"
-      ],
       "children": [
         {
           "kind": "TypeDecl",
           "name": "Context",
           "printedName": "Context",
-          "declKind": "Struct",
-          "usr": "s:s13EncodingErrorO7ContextV",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "Var",
               "name": "codingPath",
               "printedName": "codingPath",
-              "declKind": "Var",
-              "usr": "s:s13EncodingErrorO7ContextV10codingPathSays9CodingKey_pGvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<CodingKey>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -18962,22 +18289,18 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 },
                 {
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s13EncodingErrorO7ContextV10codingPathSays9CodingKey_pGvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Array",
-                      "printedName": "[CodingKey]",
-                      "usr": "s:Sa",
+                      "printedName": "Array<CodingKey>",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -18985,20 +18308,26 @@
                           "printedName": "CodingKey",
                           "usr": "s:s9CodingKeyP"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sa"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s13EncodingErrorO7ContextV10codingPathSays9CodingKey_pGvg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s13EncodingErrorO7ContextV10codingPathSays9CodingKey_pGvp",
+              "moduleName": "Swift",
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "debugDescription",
               "printedName": "debugDescription",
-              "declKind": "Var",
-              "usr": "s:s13EncodingErrorO7ContextV16debugDescriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -19010,10 +18339,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s13EncodingErrorO7ContextV16debugDescriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19021,24 +18346,28 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s13EncodingErrorO7ContextV16debugDescriptionSSvg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s13EncodingErrorO7ContextV16debugDescriptionSSvp",
+              "moduleName": "Swift",
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "underlyingError",
               "printedName": "underlyingError",
-              "declKind": "Var",
-              "usr": "s:s13EncodingErrorO7ContextV010underlyingB0s0B0_pSgvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Error?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<Error>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19046,22 +18375,18 @@
                       "printedName": "Error",
                       "usr": "s:s5ErrorP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s13EncodingErrorO7ContextV010underlyingB0s0B0_pSgvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
-                      "printedName": "Error?",
-                      "usr": "s:Sq",
+                      "printedName": "Optional<Error>",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -19069,20 +18394,26 @@
                           "printedName": "Error",
                           "usr": "s:s5ErrorP"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s13EncodingErrorO7ContextV010underlyingB0s0B0_pSgvg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s13EncodingErrorO7ContextV010underlyingB0s0B0_pSgvp",
+              "moduleName": "Swift",
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(codingPath:debugDescription:underlyingError:)",
-              "declKind": "Constructor",
-              "usr": "s:s13EncodingErrorO7ContextV10codingPath16debugDescription010underlyingB0ADSays9CodingKey_pG_SSs0B0_pSgtcfc",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -19093,8 +18424,7 @@
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<CodingKey>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19102,7 +18432,8 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 },
                 {
                   "kind": "TypeNominal",
@@ -19113,9 +18444,7 @@
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Error?",
-                  "hasDefaultArg": true,
-                  "usr": "s:Sq",
+                  "printedName": "Optional<Error>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19123,20 +18452,24 @@
                       "printedName": "Error",
                       "usr": "s:s5ErrorP"
                     }
-                  ]
+                  ],
+                  "hasDefaultArg": true,
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s13EncodingErrorO7ContextV10codingPath16debugDescription010underlyingB0ADSays9CodingKey_pG_SSs0B0_pSgtcfc",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Struct",
+          "usr": "s:s13EncodingErrorO7ContextV",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "invalidValue",
           "printedName": "invalidValue",
-          "declKind": "EnumElement",
-          "usr": "s:s13EncodingErrorO12invalidValueyAByp_AB7ContextVtcABmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -19176,65 +18509,51 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(EncodingError.Type)",
+                  "name": "Metatype",
+                  "printedName": "EncodingError.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "EncodingError.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "EncodingError",
-                          "printedName": "EncodingError",
-                          "usr": "s:s13EncodingErrorO"
-                        }
-                      ]
+                      "name": "EncodingError",
+                      "printedName": "EncodingError",
+                      "usr": "s:s13EncodingErrorO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s13EncodingErrorO12invalidValueyAByp_AB7ContextVtcABmF",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s13EncodingErrorO",
+      "moduleName": "Swift",
+      "conformingProtocols": [
+        "Error"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "DecodingError",
       "printedName": "DecodingError",
-      "declKind": "Enum",
-      "usr": "s:s13DecodingErrorO",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Error"
-      ],
       "children": [
         {
           "kind": "TypeDecl",
           "name": "Context",
           "printedName": "Context",
-          "declKind": "Struct",
-          "usr": "s:s13DecodingErrorO7ContextV",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "Var",
               "name": "codingPath",
               "printedName": "codingPath",
-              "declKind": "Var",
-              "usr": "s:s13DecodingErrorO7ContextV10codingPathSays9CodingKey_pGvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<CodingKey>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19242,22 +18561,18 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 },
                 {
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s13DecodingErrorO7ContextV10codingPathSays9CodingKey_pGvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Array",
-                      "printedName": "[CodingKey]",
-                      "usr": "s:Sa",
+                      "printedName": "Array<CodingKey>",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -19265,20 +18580,26 @@
                           "printedName": "CodingKey",
                           "usr": "s:s9CodingKeyP"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sa"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s13DecodingErrorO7ContextV10codingPathSays9CodingKey_pGvg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s13DecodingErrorO7ContextV10codingPathSays9CodingKey_pGvp",
+              "moduleName": "Swift",
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "debugDescription",
               "printedName": "debugDescription",
-              "declKind": "Var",
-              "usr": "s:s13DecodingErrorO7ContextV16debugDescriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -19290,10 +18611,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s13DecodingErrorO7ContextV16debugDescriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19301,24 +18618,28 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s13DecodingErrorO7ContextV16debugDescriptionSSvg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s13DecodingErrorO7ContextV16debugDescriptionSSvp",
+              "moduleName": "Swift",
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "underlyingError",
               "printedName": "underlyingError",
-              "declKind": "Var",
-              "usr": "s:s13DecodingErrorO7ContextV010underlyingB0s0B0_pSgvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Error?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<Error>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19326,22 +18647,18 @@
                       "printedName": "Error",
                       "usr": "s:s5ErrorP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s13DecodingErrorO7ContextV010underlyingB0s0B0_pSgvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
-                      "printedName": "Error?",
-                      "usr": "s:Sq",
+                      "printedName": "Optional<Error>",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -19349,20 +18666,26 @@
                           "printedName": "Error",
                           "usr": "s:s5ErrorP"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s13DecodingErrorO7ContextV010underlyingB0s0B0_pSgvg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s13DecodingErrorO7ContextV010underlyingB0s0B0_pSgvp",
+              "moduleName": "Swift",
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(codingPath:debugDescription:underlyingError:)",
-              "declKind": "Constructor",
-              "usr": "s:s13DecodingErrorO7ContextV10codingPath16debugDescription010underlyingB0ADSays9CodingKey_pG_SSs0B0_pSgtcfc",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -19373,8 +18696,7 @@
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<CodingKey>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19382,7 +18704,8 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 },
                 {
                   "kind": "TypeNominal",
@@ -19393,9 +18716,7 @@
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Error?",
-                  "hasDefaultArg": true,
-                  "usr": "s:Sq",
+                  "printedName": "Optional<Error>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19403,20 +18724,24 @@
                       "printedName": "Error",
                       "usr": "s:s5ErrorP"
                     }
-                  ]
+                  ],
+                  "hasDefaultArg": true,
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s13DecodingErrorO7ContextV10codingPath16debugDescription010underlyingB0ADSays9CodingKey_pG_SSs0B0_pSgtcfc",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Struct",
+          "usr": "s:s13DecodingErrorO7ContextV",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "typeMismatch",
           "printedName": "typeMismatch",
-          "declKind": "EnumElement",
-          "usr": "s:s13DecodingErrorO12typeMismatchyABypXp_AB7ContextVtcABmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -19463,36 +18788,28 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(DecodingError.Type)",
+                  "name": "Metatype",
+                  "printedName": "DecodingError.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "DecodingError.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "DecodingError",
-                          "printedName": "DecodingError",
-                          "usr": "s:s13DecodingErrorO"
-                        }
-                      ]
+                      "name": "DecodingError",
+                      "printedName": "DecodingError",
+                      "usr": "s:s13DecodingErrorO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s13DecodingErrorO12typeMismatchyABypXp_AB7ContextVtcABmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "valueNotFound",
           "printedName": "valueNotFound",
-          "declKind": "EnumElement",
-          "usr": "s:s13DecodingErrorO13valueNotFoundyABypXp_AB7ContextVtcABmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -19539,36 +18856,28 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(DecodingError.Type)",
+                  "name": "Metatype",
+                  "printedName": "DecodingError.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "DecodingError.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "DecodingError",
-                          "printedName": "DecodingError",
-                          "usr": "s:s13DecodingErrorO"
-                        }
-                      ]
+                      "name": "DecodingError",
+                      "printedName": "DecodingError",
+                      "usr": "s:s13DecodingErrorO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s13DecodingErrorO13valueNotFoundyABypXp_AB7ContextVtcABmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "keyNotFound",
           "printedName": "keyNotFound",
-          "declKind": "EnumElement",
-          "usr": "s:s13DecodingErrorO11keyNotFoundyABs9CodingKey_p_AB7ContextVtcABmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -19609,36 +18918,28 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(DecodingError.Type)",
+                  "name": "Metatype",
+                  "printedName": "DecodingError.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "DecodingError.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "DecodingError",
-                          "printedName": "DecodingError",
-                          "usr": "s:s13DecodingErrorO"
-                        }
-                      ]
+                      "name": "DecodingError",
+                      "printedName": "DecodingError",
+                      "usr": "s:s13DecodingErrorO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s13DecodingErrorO11keyNotFoundyABs9CodingKey_p_AB7ContextVtcABmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "dataCorrupted",
           "printedName": "dataCorrupted",
-          "declKind": "EnumElement",
-          "usr": "s:s13DecodingErrorO13dataCorruptedyA2B7ContextVcABmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -19658,57 +18959,36 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(DecodingError.Context)",
-                      "usr": "s:s13DecodingErrorO7ContextV",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Context",
-                          "printedName": "DecodingError.Context",
-                          "usr": "s:s13DecodingErrorO7ContextV"
-                        }
-                      ]
+                      "name": "Context",
+                      "printedName": "DecodingError.Context",
+                      "usr": "s:s13DecodingErrorO7ContextV"
                     }
                   ]
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(DecodingError.Type)",
+                  "name": "Metatype",
+                  "printedName": "DecodingError.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "DecodingError.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "DecodingError",
-                          "printedName": "DecodingError",
-                          "usr": "s:s13DecodingErrorO"
-                        }
-                      ]
+                      "name": "DecodingError",
+                      "printedName": "DecodingError",
+                      "usr": "s:s13DecodingErrorO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s13DecodingErrorO13dataCorruptedyA2B7ContextVcABmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "dataCorruptedError",
           "printedName": "dataCorruptedError(forKey:in:debugDescription:)",
-          "declKind": "Func",
-          "usr": "s:s13DecodingErrorO013dataCorruptedB06forKey2in16debugDescriptionAB0F0Qz_xSSts05KeyedA17ContainerProtocolRzlFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<C where C : KeyedDecodingContainerProtocol>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -19719,12 +18999,12 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "C.Key"
+              "printedName": "τ_0_0.Key"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "C"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -19732,20 +19012,17 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13DecodingErrorO013dataCorruptedB06forKey2in16debugDescriptionAB0F0Qz_xSSts05KeyedA17ContainerProtocolRzlFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : KeyedDecodingContainerProtocol>",
+          "static": true
         },
         {
           "kind": "Function",
           "name": "dataCorruptedError",
           "printedName": "dataCorruptedError(in:debugDescription:)",
-          "declKind": "Func",
-          "usr": "s:s13DecodingErrorO013dataCorruptedB02in16debugDescriptionABs07UnkeyedA9Container_p_SStFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -19765,20 +19042,16 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13DecodingErrorO013dataCorruptedB02in16debugDescriptionABs07UnkeyedA9Container_p_SStFZ",
+          "moduleName": "Swift",
+          "static": true
         },
         {
           "kind": "Function",
           "name": "dataCorruptedError",
           "printedName": "dataCorruptedError(in:debugDescription:)",
-          "declKind": "Func",
-          "usr": "s:s13DecodingErrorO013dataCorruptedB02in16debugDescriptionABs011SingleValueA9Container_p_SStFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -19798,351 +19071,489 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13DecodingErrorO013dataCorruptedB02in16debugDescriptionABs011SingleValueA9Container_p_SStFZ",
+          "moduleName": "Swift",
+          "static": true
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s13DecodingErrorO",
+      "moduleName": "Swift",
+      "conformingProtocols": [
+        "Error"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "IndexingIterator",
       "printedName": "IndexingIterator",
-      "declKind": "Struct",
-      "usr": "s:s16IndexingIteratorV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Elements where Elements : Collection>",
-      "conformingProtocols": [
-        "IteratorProtocol",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s16IndexingIteratorV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
+          "kind": "Var",
+          "name": "_elements",
+          "printedName": "_elements",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Elements.Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s16IndexingIteratorV0B0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
-          "children": [
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
             {
-              "kind": "TypeNominal",
-              "name": "IndexingIterator",
-              "printedName": "IndexingIterator<Elements>",
-              "usr": "s:s16IndexingIteratorV",
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Elements"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s16IndexingIteratorV9_elementsxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s16IndexingIteratorV9_elementsxvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
         },
         {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s16IndexingIteratorV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
+          "kind": "Var",
+          "name": "_position",
+          "printedName": "_position",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "AnySequence",
-              "printedName": "AnySequence<Elements.Element>",
-              "usr": "s:s11AnySequenceV",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Elements.Element"
+                  "printedName": "τ_0_0.Index"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s16IndexingIteratorV9_position5IndexQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s16IndexingIteratorV9_position5IndexQzvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "hasStorage": true
         },
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s16IndexingIteratorV4next7ElementQzSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Elements.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Elements.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16IndexingIteratorV4next7ElementQzSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ],
+          "mutating": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s16IndexingIteratorV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol",
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Collection",
       "printedName": "Collection",
-      "declKind": "Protocol",
-      "usr": "s:Sl",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Sequence, Self.Index : Comparable, Self.Index == Self.Indices.Element, Self.Indices : Collection, Self.Indices == Self.Indices.SubSequence, Self.SubSequence : Collection, Self.Indices.Element == Self.Indices.Index, Self.Indices.Index == Self.SubSequence.Index, Self.SubSequence.Index == Self.Indices.Indices.Element, Self.Indices.Indices.Element == Self.Indices.Indices.Index, Self.Indices.Indices.Index == Self.SubSequence.Indices.Element, Self.SubSequence.Indices.Element == Self.SubSequence.Indices.Index, Self.SubSequence.Indices.Index == Self.SubSequence.Indices.Indices.Element, Self.SubSequence.Indices.Indices.Element == Self.SubSequence.Indices.Indices.Index>",
-      "conformingProtocols": [
-        "Sequence"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "IndexDistance",
-          "printedName": "IndexDistance",
-          "declKind": "TypeAlias",
-          "usr": "s:Sl13IndexDistancea",
-          "location": "",
+          "kind": "AssociatedType",
+          "name": "Element",
+          "printedName": "Element",
+          "declKind": "AssociatedType",
+          "usr": "s:Sl7ElementQa",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Index",
+          "printedName": "Index",
+          "declKind": "AssociatedType",
+          "usr": "s:Sl5IndexQa",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:Sl10startIndex0B0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sl10startIndex0B0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sl10startIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sl10startIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:Sl8endIndex0B0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sl8endIndex0B0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sl8endIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sl8endIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Iterator",
+          "printedName": "Iterator",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "IndexingIterator",
+              "printedName": "IndexingIterator<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s16IndexingIteratorV"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:Sl8IteratorQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:Sl12makeIterator0B0QzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Iterator"
+              "printedName": "τ_0_0.Iterator"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl12makeIterator0B0QzyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
+          "kind": "AssociatedType",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:Sl11SubSequenceQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Sly7ElementQz5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.SubSequence"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Sly11SubSequenceQzSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Indices",
+          "printedName": "Indices",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DefaultIndices",
+              "printedName": "DefaultIndices<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SI"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:Sl7IndicesQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:Sl7indices7IndicesQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Indices"
+              "printedName": "τ_0_0.Indices"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sl7indices7IndicesQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Indices"
+                  "printedName": "τ_0_0.Indices"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sl7indices7IndicesQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sl7indices7IndicesQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(upTo:)",
-          "declKind": "Func",
-          "usr": "s:Sl6prefix4upTo11SubSequenceQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl6prefix4upTo11SubSequenceQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(from:)",
-          "declKind": "Func",
-          "usr": "s:Sl6suffix4from11SubSequenceQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl6suffix4from11SubSequenceQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(through:)",
-          "declKind": "Func",
-          "usr": "s:Sl6prefix7through11SubSequenceQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl6prefix7through11SubSequenceQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "isEmpty",
           "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:Sl7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -20154,11 +19565,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sl7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -20166,18 +19572,22 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sl7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sl7isEmptySbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:Sl5countSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -20189,11 +19599,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sl5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -20201,78 +19606,80 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sl5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sl5countSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "first",
           "printedName": "first",
-          "declKind": "Var",
-          "usr": "s:Sl5first7ElementQzSgvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sl5first7ElementQzSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Self.Element?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<τ_0_0.Element>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Element"
+                      "printedName": "τ_0_0.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sl5first7ElementQzSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sl5first7ElementQzSgvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:Sl5index_8offsetBy5IndexQzAD_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
@@ -20280,35 +19687,35 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl5index_8offsetBy5IndexQzAD_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:Sl5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Index?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
@@ -20319,19 +19726,19 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:Sl8distance4from2toSi5IndexQz_AEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -20342,46 +19749,46 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl8distance4from2toSi5IndexQz_AEtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:Sl5index5after5IndexQzAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl5index5after5IndexQzAD_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:Sl9formIndex5aftery0B0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -20391,58 +19798,54 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl9formIndex5aftery0B0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SlsE9formIndex5aftery0B0Qzz_tF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
           "declAttributes": [
             "Inline",
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Index"
-            }
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SlsE5index_8offsetBy5IndexQzAD_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
@@ -20450,38 +19853,37 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE5index_8offsetBy5IndexQzAD_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SlsE5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Index?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
@@ -20492,22 +19894,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SlsE9formIndex_8offsetByy0B0Qzz_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -20517,7 +19918,7 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
@@ -20525,20 +19926,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE9formIndex_8offsetByy0B0Qzz_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SlsE9formIndex_8offsetBy07limitedD0Sb0B0Qzz_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -20549,7 +19949,7 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
@@ -20560,22 +19960,21 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE9formIndex_8offsetBy07limitedD0Sb0B0Qzz_SiAEtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SlsE8distance4from2toSi5IndexQz_AEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -20586,145 +19985,181 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE8distance4from2toSi5IndexQz_AEtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "randomElement",
           "printedName": "randomElement(using:)",
-          "declKind": "Func",
-          "usr": "s:SlsE13randomElement5using0B0QzSgqd__z_tSGRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Collection, T : RandomNumberGenerator>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE13randomElement5using0B0QzSgqd__z_tSGRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Collection, τ_1_0 : RandomNumberGenerator>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "randomElement",
           "printedName": "randomElement()",
-          "declKind": "Func",
-          "usr": "s:SlsE13randomElement0B0QzSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE13randomElement0B0QzSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:Slss16IndexingIteratorVyxG0B0RtzrlE04makeB0ACyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection, Self.Iterator == IndexingIterator<Self>>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "IndexingIterator",
-              "printedName": "IndexingIterator<Self>",
-              "usr": "s:s16IndexingIteratorV",
+              "printedName": "IndexingIterator<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s16IndexingIteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Slss16IndexingIteratorVyxG0B0RtzrlE04makeB0ACyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Iterator == IndexingIterator<τ_0_0>>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Slss5SliceVyxG11SubSequenceRtzrlEyACSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.SubSequence == Slice<τ_0_0>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "popFirst",
           "printedName": "popFirst()",
-          "declKind": "Func",
-          "usr": "s:Sls11SubSequenceQzRszrlE8popFirst7ElementQzSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sls11SubSequenceQzRszrlE8popFirst7ElementQzSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0 == τ_0_0.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Var",
           "name": "isEmpty",
           "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:SlsE7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -20736,11 +20171,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SlsE7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -20748,76 +20178,77 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SlsE7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SlsE7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "first",
           "printedName": "first",
-          "declKind": "Var",
-          "usr": "s:SlsE5first7ElementQzSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SlsE5first7ElementQzSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
-              "declAttributes": [
-                "Inline"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Self.Element?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<τ_0_0.Element>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Element"
+                      "printedName": "τ_0_0.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SlsE5first7ElementQzSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "declAttributes": [
+                "Inline"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SlsE5first7ElementQzSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:SlsE19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -20829,11 +20260,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SlsE19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -20841,21 +20267,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SlsE19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SlsE19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:SlsE5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -20867,11 +20296,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SlsE5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -20879,84 +20303,78 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SlsE5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SlsE5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:SlsE3mapySayqd__Gqd__7ElementQzKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Collection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[T]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> T",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> τ_1_0",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE3mapySayqd__Gqd__7ElementQzKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:SlsE9dropFirsty11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
@@ -20964,25 +20382,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE9dropFirsty11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:SlsE8dropLasty11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
@@ -20990,35 +20407,29 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE8dropLasty11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:SlsE4drop5while11SubSequenceQzSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -21028,37 +20439,34 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE4drop5while11SubSequenceQzSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(_:)",
-          "declKind": "Func",
-          "usr": "s:SlsE6prefixy11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
@@ -21066,35 +20474,29 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE6prefixy11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:SlsE6prefix5while11SubSequenceQzSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -21104,37 +20506,34 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE6prefix5while11SubSequenceQzSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:SlsE6suffixy11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
@@ -21142,110 +20541,104 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE6suffixy11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(upTo:)",
-          "declKind": "Func",
-          "usr": "s:SlsE6prefix4upTo11SubSequenceQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE6prefix4upTo11SubSequenceQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(from:)",
-          "declKind": "Func",
-          "usr": "s:SlsE6suffix4from11SubSequenceQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE6suffix4from11SubSequenceQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(through:)",
-          "declKind": "Func",
-          "usr": "s:SlsE6prefix7through11SubSequenceQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE6prefix7through11SubSequenceQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(maxSplits:omittingEmptySubsequences:whereSeparator:)",
-          "declKind": "Func",
-          "usr": "s:SlsE5split9maxSplits25omittingEmptySubsequences14whereSeparatorSay11SubSequenceQzGSi_S2b7ElementQzKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Self.SubSequence]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0.SubSequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.SubSequence"
+                  "printedName": "τ_0_0.SubSequence"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -21264,10 +20657,7 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -21277,50 +20667,47 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE5split9maxSplits25omittingEmptySubsequences14whereSeparatorSay11SubSequenceQzGSi_S2b7ElementQzKXEtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(separator:maxSplits:omittingEmptySubsequences:)",
-          "declKind": "Func",
-          "usr": "s:SlsSQ7ElementRpzrlE5split9separator9maxSplits25omittingEmptySubsequencesSay11SubSequenceQzGAB_SiSbtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection, Self.Element : Equatable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Self.SubSequence]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0.SubSequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.SubSequence"
+                  "printedName": "τ_0_0.SubSequence"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             },
             {
               "kind": "TypeNominal",
@@ -21336,43 +20723,40 @@
               "hasDefaultArg": true,
               "usr": "s:Sb"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsSQ7ElementRpzrlE5split9separator9maxSplits25omittingEmptySubsequencesSay11SubSequenceQzGAB_SiSbtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Equatable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "removeFirst",
           "printedName": "removeFirst()",
-          "declKind": "Func",
-          "usr": "s:Sls11SubSequenceQzRszrlE11removeFirst7ElementQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sls11SubSequenceQzRszrlE11removeFirst7ElementQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0 == τ_0_0.SubSequence>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeFirst",
           "printedName": "removeFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:Sls11SubSequenceQzRszrlE11removeFirstyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -21385,76 +20769,70 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sls11SubSequenceQzRszrlE11removeFirstyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0 == τ_0_0.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "firstIndex",
           "printedName": "firstIndex(of:)",
-          "declKind": "Func",
-          "usr": "s:SlsSQ7ElementRpzrlE10firstIndex2of0C0QzSgAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection, Self.Element : Equatable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Index?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsSQ7ElementRpzrlE10firstIndex2of0C0QzSgAB_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Equatable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "firstIndex",
           "printedName": "firstIndex(where:)",
-          "declKind": "Func",
-          "usr": "s:SlsE10firstIndex5where0B0QzSgSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Index?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -21464,196 +20842,250 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE10firstIndex5where0B0QzSgSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "joined",
           "printedName": "joined()",
-          "declKind": "Func",
-          "usr": "s:SlsSl7ElementRpzrlE6joineds17FlattenCollectionVyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection, Self.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "FlattenCollection",
-              "printedName": "FlattenCollection<Self>",
-              "usr": "s:s17FlattenCollectionV",
+              "printedName": "FlattenCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s17FlattenCollectionV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsSl7ElementRpzrlE6joineds17FlattenCollectionVyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:SlsSIyxG7IndicesRtzrlE7indicesAAvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DefaultIndices",
-              "printedName": "DefaultIndices<Self>",
-              "usr": "s:SI",
+              "printedName": "DefaultIndices<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:SI"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SlsSIyxG7IndicesRtzrlE7indicesAAvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection, Self.Indices == DefaultIndices<Self>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DefaultIndices",
-                  "printedName": "DefaultIndices<Self>",
-                  "usr": "s:SI",
+                  "printedName": "DefaultIndices<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Self"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:SI"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SlsSIyxG7IndicesRtzrlE7indicesAAvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Indices == DefaultIndices<τ_0_0>>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SlsSIyxG7IndicesRtzrlE7indicesAAvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "lazy",
           "printedName": "lazy",
-          "declKind": "Var",
-          "usr": "s:SlsE4lazys14LazyCollectionVyxGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyCollection",
-              "printedName": "LazyCollection<Self>",
-              "usr": "s:s14LazyCollectionV",
+              "printedName": "LazyCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s14LazyCollectionV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SlsE4lazys14LazyCollectionVyxGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "LazyCollection",
-                  "printedName": "LazyCollection<Self>",
-                  "usr": "s:s14LazyCollectionV",
+                  "printedName": "LazyCollection<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Self"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s14LazyCollectionV"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SlsE4lazys14LazyCollectionVyxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SlsE4lazys14LazyCollectionVyxGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.SubSequence"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SlsEy11SubSequenceQzqd__cSXRd__5BoundQyd__5IndexRtzluip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Collection, τ_1_0 : RangeExpression, τ_0_0.Index == τ_1_0.Bound>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.SubSequence"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnboundedRange_) -> ()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnboundedRange_",
+                  "printedName": "UnboundedRange_",
+                  "usr": "s:s15UnboundedRange_O"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SlsEy11SubSequenceQzys15UnboundedRange_OXEcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SlsE5index_8offsetBy5IndexQzAD_qd__tSzRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Collection, T : BinaryInteger>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE5index_8offsetBy5IndexQzAD_qd__tSzRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Collection, τ_1_0 : BinaryInteger>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SlsE9formIndex_8offsetByy0B0Qzz_qd__tSzRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Collection, T : BinaryInteger>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -21663,72 +21095,70 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE9formIndex_8offsetByy0B0Qzz_qd__tSzRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Collection, τ_1_0 : BinaryInteger>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SlsE5index_8offsetBy07limitedC05IndexQzSgAE_qd__AEtSzRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Collection, T : BinaryInteger>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Index?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE5index_8offsetBy07limitedC05IndexQzSgAE_qd__AEtSzRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Collection, τ_1_0 : BinaryInteger>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SlsE9formIndex_8offsetBy07limitedD0Sb0B0Qzz_qd__AEtSzRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Collection, T : BinaryInteger>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -21739,71 +21169,67 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE9formIndex_8offsetBy07limitedD0Sb0B0Qzz_qd__AEtSzRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Collection, τ_1_0 : BinaryInteger>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SlsE8distance4from2toqd__5IndexQz_AEtSzRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Collection, T : BinaryInteger>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE8distance4from2toqd__5IndexQz_AEtSzRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Collection, τ_1_0 : BinaryInteger>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "flatMap",
           "printedName": "flatMap(_:)",
-          "declKind": "Func",
-          "usr": "s:SlsE7flatMapySaySSGSSSg7ElementQzKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[String]",
-              "usr": "s:Sa",
+              "printedName": "Array<String>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -21811,21 +21237,18 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> String?",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Optional<String>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "String?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<String>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -21833,35 +21256,470 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE7flatMapySaySSGSSSg7ElementQzKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "deprecated": true,
+          "declAttributes": [
+            "Rethrows",
+            "Available"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsSQ7ElementRpzrlE5index2of5IndexQzSgAB_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Equatable>",
+          "declAttributes": [
+            "Inlinable",
+            "Available"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:Sl",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : Sequence, τ_0_0.Index : Comparable, τ_0_0.Index == τ_0_0.Indices.Element, τ_0_0.Indices : Collection, τ_0_0.Indices == τ_0_0.Indices.SubSequence, τ_0_0.SubSequence : Collection, τ_0_0.Indices.Element == τ_0_0.Indices.Index, τ_0_0.Indices.Index == τ_0_0.SubSequence.Index, τ_0_0.SubSequence.Index == τ_0_0.Indices.Indices.Element, τ_0_0.Indices.Indices.Element == τ_0_0.Indices.Indices.Index, τ_0_0.Indices.Indices.Index == τ_0_0.SubSequence.Indices.Element, τ_0_0.SubSequence.Indices.Element == τ_0_0.SubSequence.Indices.Index, τ_0_0.SubSequence.Indices.Index == τ_0_0.SubSequence.Indices.Indices.Element, τ_0_0.SubSequence.Indices.Indices.Element == τ_0_0.SubSequence.Indices.Indices.Index>",
+      "conformingProtocols": [
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Comparable",
       "printedName": "Comparable",
+      "children": [
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SL1loiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SL2leoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SL2geoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SL1goiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SLsE1goiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SLsE2leoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SLsE2geoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "...",
+          "printedName": "...(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SN"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SLsE3zzzoiySNyxGx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "..<",
+          "printedName": "..<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SLsE3zzloiySnyxGx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "..<",
+          "printedName": "..<(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "PartialRangeUpTo",
+              "printedName": "PartialRangeUpTo<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s16PartialRangeUpToV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SLsE3zzlopys16PartialRangeUpToVyxGxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "...",
+          "printedName": "...(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "PartialRangeThrough",
+              "printedName": "PartialRangeThrough<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s19PartialRangeThroughV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SLsE3zzzopys19PartialRangeThroughVyxGxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "...",
+          "printedName": "...(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "PartialRangeFrom",
+              "printedName": "PartialRangeFrom<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s16PartialRangeFromV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SLsE3zzzoPys16PartialRangeFromVyxGxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Postfix",
+            "Transparent"
+          ]
+        }
+      ],
       "declKind": "Protocol",
       "usr": "s:SL",
-      "location": "",
       "moduleName": "Swift",
-      "genericSig": "<Self : Equatable>",
+      "genericSig": "<τ_0_0 : Equatable>",
       "conformingProtocols": [
         "Equatable"
       ]
@@ -21870,767 +21728,662 @@
       "kind": "TypeDecl",
       "name": "RawRepresentable",
       "printedName": "RawRepresentable",
-      "declKind": "Protocol",
-      "usr": "s:SY",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "RawValue",
+          "printedName": "RawValue",
+          "declKind": "AssociatedType",
+          "usr": "s:SY8RawValueQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(rawValue:)",
-          "declKind": "Constructor",
-          "usr": "s:SY8rawValuexSg03RawB0Qz_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RawRepresentable>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.RawValue"
+              "printedName": "τ_0_0.RawValue"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SY8rawValuexSg03RawB0Qz_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RawRepresentable>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "rawValue",
           "printedName": "rawValue",
-          "declKind": "Var",
-          "usr": "s:SY8rawValue03RawB0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.RawValue"
+              "printedName": "τ_0_0.RawValue"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SY8rawValue03RawB0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : RawRepresentable>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.RawValue"
+                  "printedName": "τ_0_0.RawValue"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SY8rawValue03RawB0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : RawRepresentable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SY8rawValue03RawB0Qzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzSb8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == Bool>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == Bool>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzSb8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == Bool>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == Bool>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzSS8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == String>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == String>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzSS8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == String>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == String>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzSd8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == Double>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == Double>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzSd8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == Double>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == Double>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzSf8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == Float>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == Float>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzSf8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == Float>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == Float>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzSi8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == Int>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == Int>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzSi8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == Int>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == Int>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzs4Int8V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == Int8>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == Int8>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzs4Int8V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == Int8>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == Int8>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzs5Int16V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == Int16>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == Int16>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzs5Int16V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == Int16>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == Int16>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzs5Int32V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == Int32>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == Int32>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzs5Int32V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == Int32>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == Int32>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzs5Int64V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == Int64>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == Int64>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzs5Int64V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == Int64>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == Int64>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzSu8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == UInt>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == UInt>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzSu8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == UInt>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == UInt>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzs5UInt8V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == UInt8>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == UInt8>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzs5UInt8V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == UInt8>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == UInt8>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzs6UInt16V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == UInt16>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == UInt16>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzs6UInt16V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == UInt16>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == UInt16>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzs6UInt32V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == UInt32>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == UInt32>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:SYsSeRzs6UInt32V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == UInt32>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -22638,21 +22391,17 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SYsSeRzs6UInt32V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == UInt32>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:SYsSERzs6UInt64V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == UInt64>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -22665,26 +22414,22 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SYsSERzs6UInt64V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == UInt64>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:SYsSeRzs6UInt64V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == UInt64>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -22692,500 +22437,1865 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SYsSeRzs6UInt64V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable, τ_0_0 : RawRepresentable, τ_0_0.RawValue == UInt64>",
+          "throwing": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SY",
+      "moduleName": "Swift"
+    },
+    {
+      "kind": "Function",
+      "name": "==",
+      "printedName": "==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2eeoiySbx_xtSYRzSQ8RawValueRpzlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : RawRepresentable, τ_0_0.RawValue : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbx_xtSYRzSQ8RawValueRpzlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : RawRepresentable, τ_0_0.RawValue : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbx_xtSQRzSYRzSQ8RawValueSYRpzlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Equatable, τ_0_0 : RawRepresentable, τ_0_0.RawValue : Equatable>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "CaseIterable",
       "printedName": "CaseIterable",
-      "declKind": "Protocol",
-      "usr": "s:s12CaseIterableP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self == Self.AllCases.Element, Self.AllCases : Collection>",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "AllCases",
+          "printedName": "AllCases",
+          "declKind": "AssociatedType",
+          "usr": "s:s12CaseIterableP8AllCasesQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Var",
           "name": "allCases",
           "printedName": "allCases",
-          "declKind": "Var",
-          "usr": "s:s12CaseIterableP8allCases03AllD0QzvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.AllCases"
+              "printedName": "τ_0_0.AllCases"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12CaseIterableP8allCases03AllD0QzvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CaseIterable>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.AllCases"
+                  "printedName": "τ_0_0.AllCases"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12CaseIterableP8allCases03AllD0QzvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : CaseIterable>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s12CaseIterableP8allCases03AllD0QzvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s12CaseIterableP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 == τ_0_0.AllCases.Element, τ_0_0.AllCases : Collection>"
     },
     {
       "kind": "TypeDecl",
       "name": "ExpressibleByNilLiteral",
       "printedName": "ExpressibleByNilLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s23ExpressibleByNilLiteralP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(nilLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s23ExpressibleByNilLiteralP03nilD0xyt_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByNilLiteral>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s23ExpressibleByNilLiteralP03nilD0xyt_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : ExpressibleByNilLiteral>",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s23ExpressibleByNilLiteralP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "ExpressibleByIntegerLiteral",
       "printedName": "ExpressibleByIntegerLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s27ExpressibleByIntegerLiteralP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self.IntegerLiteralType : _ExpressibleByBuiltinIntegerLiteral>",
       "children": [
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(integerLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s27ExpressibleByIntegerLiteralP07integerD0x0cD4TypeQz_tcfc",
-          "location": "",
+          "kind": "AssociatedType",
+          "name": "IntegerLiteralType",
+          "printedName": "IntegerLiteralType",
+          "declKind": "AssociatedType",
+          "usr": "s:s27ExpressibleByIntegerLiteralP0cD4TypeQa",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByIntegerLiteral>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.IntegerLiteralType"
-            }
-          ]
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(integerLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s27ExpressibleByIntegerLiteralPss01_ab7BuiltincD0RzrlE07integerD0xx_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByIntegerLiteral, Self : _ExpressibleByBuiltinIntegerLiteral>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.IntegerLiteralType"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s27ExpressibleByIntegerLiteralP07integerD0x0cD4TypeQz_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : ExpressibleByIntegerLiteral>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(integerLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s27ExpressibleByIntegerLiteralPss01_ab7BuiltincD0RzrlE07integerD0xx_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : ExpressibleByIntegerLiteral, τ_0_0 : _ExpressibleByBuiltinIntegerLiteral>",
+          "declAttributes": [
+            "Transparent"
           ]
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s27ExpressibleByIntegerLiteralP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0.IntegerLiteralType : _ExpressibleByBuiltinIntegerLiteral>"
     },
     {
       "kind": "TypeDecl",
       "name": "ExpressibleByFloatLiteral",
       "printedName": "ExpressibleByFloatLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s25ExpressibleByFloatLiteralP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self.FloatLiteralType : _ExpressibleByBuiltinFloatLiteral>",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "FloatLiteralType",
+          "printedName": "FloatLiteralType",
+          "declKind": "AssociatedType",
+          "usr": "s:s25ExpressibleByFloatLiteralP0cD4TypeQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(floatLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s25ExpressibleByFloatLiteralP05floatD0x0cD4TypeQz_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByFloatLiteral>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.FloatLiteralType"
+              "printedName": "τ_0_0.FloatLiteralType"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s25ExpressibleByFloatLiteralP05floatD0x0cD4TypeQz_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : ExpressibleByFloatLiteral>",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s25ExpressibleByFloatLiteralP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0.FloatLiteralType : _ExpressibleByBuiltinFloatLiteral>"
     },
     {
       "kind": "TypeDecl",
       "name": "ExpressibleByBooleanLiteral",
       "printedName": "ExpressibleByBooleanLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s27ExpressibleByBooleanLiteralP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self.BooleanLiteralType : _ExpressibleByBuiltinBooleanLiteral>",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "BooleanLiteralType",
+          "printedName": "BooleanLiteralType",
+          "declKind": "AssociatedType",
+          "usr": "s:s27ExpressibleByBooleanLiteralP0cD4TypeQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(booleanLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s27ExpressibleByBooleanLiteralP07booleanD0x0cD4TypeQz_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByBooleanLiteral>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.BooleanLiteralType"
+              "printedName": "τ_0_0.BooleanLiteralType"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s27ExpressibleByBooleanLiteralP07booleanD0x0cD4TypeQz_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : ExpressibleByBooleanLiteral>",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s27ExpressibleByBooleanLiteralP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0.BooleanLiteralType : _ExpressibleByBuiltinBooleanLiteral>"
     },
     {
       "kind": "TypeDecl",
       "name": "ExpressibleByUnicodeScalarLiteral",
       "printedName": "ExpressibleByUnicodeScalarLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s33ExpressibleByUnicodeScalarLiteralP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self.UnicodeScalarLiteralType : _ExpressibleByBuiltinUnicodeScalarLiteral>",
       "children": [
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(unicodeScalarLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s33ExpressibleByUnicodeScalarLiteralP07unicodedE0x0cdE4TypeQz_tcfc",
-          "location": "",
+          "kind": "AssociatedType",
+          "name": "UnicodeScalarLiteralType",
+          "printedName": "UnicodeScalarLiteralType",
+          "declKind": "AssociatedType",
+          "usr": "s:s33ExpressibleByUnicodeScalarLiteralP0cdE4TypeQa",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByUnicodeScalarLiteral>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.UnicodeScalarLiteralType"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "ExpressibleByExtendedGraphemeClusterLiteral",
-      "printedName": "ExpressibleByExtendedGraphemeClusterLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s43ExpressibleByExtendedGraphemeClusterLiteralP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : ExpressibleByUnicodeScalarLiteral, Self.ExtendedGraphemeClusterLiteralType : _ExpressibleByBuiltinExtendedGraphemeClusterLiteral>",
-      "conformingProtocols": [
-        "ExpressibleByUnicodeScalarLiteral"
-      ],
-      "children": [
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(extendedGraphemeClusterLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s43ExpressibleByExtendedGraphemeClusterLiteralP08extendeddeF0x0cdeF4TypeQz_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByExtendedGraphemeClusterLiteral>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.ExtendedGraphemeClusterLiteralType"
-            }
-          ]
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(unicodeScalarLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s43ExpressibleByExtendedGraphemeClusterLiteralPs013UnicodeScalarF4TypeQz0cdefI0RtzrlE07unicodehF0xAF_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByExtendedGraphemeClusterLiteral, Self.ExtendedGraphemeClusterLiteralType == Self.UnicodeScalarLiteralType>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.ExtendedGraphemeClusterLiteralType"
+              "printedName": "τ_0_0.UnicodeScalarLiteralType"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s33ExpressibleByUnicodeScalarLiteralP07unicodedE0x0cdE4TypeQz_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : ExpressibleByUnicodeScalarLiteral>",
+          "protocolReq": true
+        }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s33ExpressibleByUnicodeScalarLiteralP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0.UnicodeScalarLiteralType : _ExpressibleByBuiltinUnicodeScalarLiteral>"
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "ExpressibleByExtendedGraphemeClusterLiteral",
+      "printedName": "ExpressibleByExtendedGraphemeClusterLiteral",
+      "children": [
+        {
+          "kind": "AssociatedType",
+          "name": "ExtendedGraphemeClusterLiteralType",
+          "printedName": "ExtendedGraphemeClusterLiteralType",
+          "declKind": "AssociatedType",
+          "usr": "s:s43ExpressibleByExtendedGraphemeClusterLiteralP0cdeF4TypeQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(extendedGraphemeClusterLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.ExtendedGraphemeClusterLiteralType"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s43ExpressibleByExtendedGraphemeClusterLiteralP08extendeddeF0x0cdeF4TypeQz_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : ExpressibleByExtendedGraphemeClusterLiteral>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(unicodeScalarLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.ExtendedGraphemeClusterLiteralType"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s43ExpressibleByExtendedGraphemeClusterLiteralPs013UnicodeScalarF4TypeQz0cdefI0RtzrlE07unicodehF0xAF_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : ExpressibleByExtendedGraphemeClusterLiteral, τ_0_0.ExtendedGraphemeClusterLiteralType == τ_0_0.UnicodeScalarLiteralType>",
+          "declAttributes": [
+            "Transparent"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s43ExpressibleByExtendedGraphemeClusterLiteralP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : ExpressibleByUnicodeScalarLiteral, τ_0_0.ExtendedGraphemeClusterLiteralType : _ExpressibleByBuiltinExtendedGraphemeClusterLiteral>",
+      "conformingProtocols": [
+        "ExpressibleByUnicodeScalarLiteral"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "ExpressibleByStringLiteral",
       "printedName": "ExpressibleByStringLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s26ExpressibleByStringLiteralP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : ExpressibleByExtendedGraphemeClusterLiteral, Self.StringLiteralType : _ExpressibleByBuiltinStringLiteral>",
-      "conformingProtocols": [
-        "ExpressibleByExtendedGraphemeClusterLiteral",
-        "ExpressibleByUnicodeScalarLiteral"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "StringLiteralType",
+          "printedName": "StringLiteralType",
+          "declKind": "AssociatedType",
+          "usr": "s:s26ExpressibleByStringLiteralP0cD4TypeQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(stringLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s26ExpressibleByStringLiteralP06stringD0x0cD4TypeQz_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByStringLiteral>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.StringLiteralType"
+              "printedName": "τ_0_0.StringLiteralType"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s26ExpressibleByStringLiteralP06stringD0x0cD4TypeQz_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : ExpressibleByStringLiteral>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(extendedGraphemeClusterLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s26ExpressibleByStringLiteralPs0cD4TypeQz023ExtendedGraphemeClusterdE0RtzrlE08extendedghD0xAF_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByStringLiteral, Self.ExtendedGraphemeClusterLiteralType == Self.StringLiteralType>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.StringLiteralType"
+              "printedName": "τ_0_0.StringLiteralType"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s26ExpressibleByStringLiteralPs0cD4TypeQz023ExtendedGraphemeClusterdE0RtzrlE08extendedghD0xAF_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : ExpressibleByStringLiteral, τ_0_0.ExtendedGraphemeClusterLiteralType == τ_0_0.StringLiteralType>",
+          "declAttributes": [
+            "Transparent"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s26ExpressibleByStringLiteralP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : ExpressibleByExtendedGraphemeClusterLiteral, τ_0_0.StringLiteralType : _ExpressibleByBuiltinStringLiteral>",
+      "conformingProtocols": [
+        "ExpressibleByExtendedGraphemeClusterLiteral",
+        "ExpressibleByUnicodeScalarLiteral"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "ExpressibleByArrayLiteral",
       "printedName": "ExpressibleByArrayLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s25ExpressibleByArrayLiteralP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "ArrayLiteralElement",
+          "printedName": "ArrayLiteralElement",
+          "declKind": "AssociatedType",
+          "usr": "s:s25ExpressibleByArrayLiteralP0cD7ElementQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(arrayLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s25ExpressibleByArrayLiteralP05arrayD0x0cD7ElementQzd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByArrayLiteral>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Self.ArrayLiteralElement]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0.ArrayLiteralElement>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.ArrayLiteralElement"
+                  "printedName": "τ_0_0.ArrayLiteralElement"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s25ExpressibleByArrayLiteralP05arrayD0x0cD7ElementQzd_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : ExpressibleByArrayLiteral>",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s25ExpressibleByArrayLiteralP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "ExpressibleByDictionaryLiteral",
       "printedName": "ExpressibleByDictionaryLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s30ExpressibleByDictionaryLiteralP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Key",
+          "printedName": "Key",
+          "declKind": "AssociatedType",
+          "usr": "s:s30ExpressibleByDictionaryLiteralP3KeyQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Value",
+          "printedName": "Value",
+          "declKind": "AssociatedType",
+          "usr": "s:s30ExpressibleByDictionaryLiteralP5ValueQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(dictionaryLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s30ExpressibleByDictionaryLiteralP010dictionaryD0x3KeyQz_5ValueQztd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByDictionaryLiteral>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[(Self.Key, Self.Value)]",
-              "usr": "s:Sa",
+              "printedName": "Array<(τ_0_0.Key, τ_0_0.Value)>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Tuple",
-                  "printedName": "(Self.Key, Self.Value)",
+                  "printedName": "(τ_0_0.Key, τ_0_0.Value)",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Key"
+                      "printedName": "τ_0_0.Key"
                     },
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Value"
+                      "printedName": "τ_0_0.Value"
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s30ExpressibleByDictionaryLiteralP010dictionaryD0x3KeyQz_5ValueQztd_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : ExpressibleByDictionaryLiteral>",
+          "protocolReq": true
         }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "ExpressibleByStringInterpolation",
-      "printedName": "ExpressibleByStringInterpolation",
-      "declKind": "TypeAlias",
-      "usr": "s:s32ExpressibleByStringInterpolationa",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
       ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "_ExpressibleByStringInterpolation",
-          "printedName": "_ExpressibleByStringInterpolation",
-          "usr": "s:s33_ExpressibleByStringInterpolationP"
-        }
-      ]
+      "declKind": "Protocol",
+      "usr": "s:s30ExpressibleByDictionaryLiteralP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "ContiguousArray",
       "printedName": "ContiguousArray",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_buffer",
+          "printedName": "_buffer",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "_ContiguousArrayBuffer",
+              "printedName": "_ContiguousArrayBuffer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s22_ContiguousArrayBufferV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_ContiguousArrayBuffer",
+                  "printedName": "_ContiguousArrayBuffer<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:s22_ContiguousArrayBufferV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15ContiguousArrayV7_buffers01_aB6BufferVyxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15ContiguousArrayV7_buffers01_aB6BufferVyxGvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15ContiguousArrayV10startIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15ContiguousArrayV10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15ContiguousArrayV8endIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15ContiguousArrayV8endIndexSivp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV5index5afterS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV9formIndex5afterySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV5index6beforeS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV9formIndex6beforeySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV5index_8offsetByS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:limitedBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV5index_8offsetBy07limitedE0SiSgSi_S2itF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(from:to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV8distance4from2toS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s15ContiguousArrayVyxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ArraySlice",
+              "printedName": "ArraySlice<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s10ArraySliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s15ContiguousArrayVys0B5SliceVyxGSnySiGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(arrayLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ContiguousArray",
+              "printedName": "ContiguousArray<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s15ContiguousArrayV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sa"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s15ContiguousArrayV12arrayLiteralAByxGxd_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ContiguousArray",
+              "printedName": "ContiguousArray<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s15ContiguousArrayV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s15ContiguousArrayVAByxGycfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ContiguousArray",
+              "printedName": "ContiguousArray<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s15ContiguousArrayV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s15ContiguousArrayVyAByxGqd__c7ElementQyd__RszSTRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(repeating:count:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ContiguousArray",
+              "printedName": "ContiguousArray<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s15ContiguousArrayV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s15ContiguousArrayV9repeating5countAByxGx_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "count",
+          "printedName": "count",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15ContiguousArrayV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15ContiguousArrayV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "capacity",
+          "printedName": "capacity",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15ContiguousArrayV8capacitySivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15ContiguousArrayV8capacitySivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "reserveCapacity",
+          "printedName": "reserveCapacity(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV15reserveCapacityyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "append",
+          "printedName": "append(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV6appendyyxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "append",
+          "printedName": "append(contentsOf:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV6append10contentsOfyqd___t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "remove",
+          "printedName": "remove(at:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV6remove2atxSi_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "insert",
+          "printedName": "insert(_:at:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV6insert_2atyxn_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "removeAll",
+          "printedName": "removeAll(keepingCapacity:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "hasDefaultArg": true,
+              "usr": "s:Sb"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV9removeAll15keepingCapacityySb_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Var",
+          "name": "customMirror",
+          "printedName": "customMirror",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Mirror",
+              "printedName": "Mirror",
+              "usr": "s:s6MirrorV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15ContiguousArrayV12customMirrors0D0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15ContiguousArrayV12customMirrors0D0Vvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "description",
+          "printedName": "description",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15ContiguousArrayV11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15ContiguousArrayV11descriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15ContiguousArrayV16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15ContiguousArrayV16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeBufferPointer",
+          "printedName": "withUnsafeBufferPointer(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafeBufferPointer<τ_0_0>) throws -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeBufferPointer",
+                  "printedName": "UnsafeBufferPointer<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:SR"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV23withUnsafeBufferPointeryqd__qd__SRyxGKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeMutableBufferPointer",
+          "printedName": "withUnsafeMutableBufferPointer(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(inout UnsafeMutableBufferPointer<τ_0_0>) throws -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "InOut",
+                  "printedName": "inout UnsafeMutableBufferPointer<τ_0_0>"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV30withUnsafeMutableBufferPointeryqd__qd__SryxGzKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inline",
+            "Semantics"
+          ],
+          "throwing": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "replaceSubrange",
+          "printedName": "replaceSubrange(_:with:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV15replaceSubrange_4withySnySiG_qd__nt7ElementQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : Collection>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ContiguousArray",
+              "printedName": "ContiguousArray<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s15ContiguousArrayV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ContiguousArray",
+              "printedName": "ContiguousArray<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s15ContiguousArrayV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayVsSQRzlE2eeoiySbAByxG_ADtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Equatable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "hash",
+          "printedName": "hash(into:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Hasher",
+              "printedName": "Hasher",
+              "usr": "s:s6HasherV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayVsSHRzlE4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "hashValue",
+          "printedName": "hashValue",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15ContiguousArrayVsSHRzlE9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+              "implicit": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15ContiguousArrayVsSHRzlE9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeMutableBytes",
+          "printedName": "withUnsafeMutableBytes(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafeMutableRawBufferPointer) throws -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutableRawBufferPointer",
+                  "printedName": "UnsafeMutableRawBufferPointer",
+                  "usr": "s:Sw"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV22withUnsafeMutableBytesyqd__qd__SwKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeBytes",
+          "printedName": "withUnsafeBytes(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafeRawBufferPointer) throws -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeRawBufferPointer",
+                  "printedName": "UnsafeRawBufferPointer",
+                  "usr": "s:SW"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV15withUnsafeBytesyqd__qd__SWKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        }
+      ],
       "declKind": "Struct",
       "usr": "s:s15ContiguousArrayV",
-      "location": "",
       "moduleName": "Swift",
-      "genericSig": "<Element>",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "_DestructorSafeContainer",
         "RandomAccessCollection",
@@ -23201,1464 +24311,137 @@
         "CustomDebugStringConvertible",
         "Equatable",
         "Hashable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s15ContiguousArrayV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s15ContiguousArrayV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Int>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s15ContiguousArrayV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "IndexingIterator",
-              "printedName": "IndexingIterator<ContiguousArray<Element>>",
-              "usr": "s:s16IndexingIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "ContiguousArray",
-                  "printedName": "ContiguousArray<Element>",
-                  "usr": "s:s15ContiguousArrayV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s15ContiguousArrayV10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15ContiguousArrayV10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s15ContiguousArrayV8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15ContiguousArrayV8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV5index5afterS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV9formIndex5afterySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV5index6beforeS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV9formIndex6beforeySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV5index_8offsetByS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV5index_8offsetBy07limitedE0SiSgSi_S2itF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV8distance4from2toS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s15ContiguousArrayV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s15ContiguousArrayV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ArraySlice",
-              "printedName": "ArraySlice<Element>",
-              "usr": "s:s10ArraySliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(arrayLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s15ContiguousArrayV12arrayLiteralAByxGxd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ContiguousArray",
-              "printedName": "ContiguousArray<Element>",
-              "usr": "s:s15ContiguousArrayV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "[ContiguousArray<Element>.Element]",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "ContiguousArray<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "ArrayLiteralElement",
-          "printedName": "ArrayLiteralElement",
-          "declKind": "TypeAlias",
-          "usr": "s:s15ContiguousArrayV0B14LiteralElementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s15ContiguousArrayVAByxGycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ContiguousArray",
-              "printedName": "ContiguousArray<Element>",
-              "usr": "s:s15ContiguousArrayV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s15ContiguousArrayVyAByxGqd__c7ElementQyd__RszSTRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ContiguousArray",
-              "printedName": "ContiguousArray<Element>",
-              "usr": "s:s15ContiguousArrayV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(repeating:count:)",
-          "declKind": "Constructor",
-          "usr": "s:s15ContiguousArrayV9repeating5countAByxGx_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ContiguousArray",
-              "printedName": "ContiguousArray<Element>",
-              "usr": "s:s15ContiguousArrayV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "ContiguousArray<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "count",
-          "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s15ContiguousArrayV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15ContiguousArrayV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "capacity",
-          "printedName": "capacity",
-          "declKind": "Var",
-          "usr": "s:s15ContiguousArrayV8capacitySivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15ContiguousArrayV8capacitySivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "reserveCapacity",
-          "printedName": "reserveCapacity(_:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV15reserveCapacityyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "append",
-          "printedName": "append(_:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV6appendyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "ContiguousArray<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "append",
-          "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV6append10contentsOfyqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "remove",
-          "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV6remove2atxSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "ContiguousArray<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "insert",
-          "printedName": "insert(_:at:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV6insert_2atyx_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "ContiguousArray<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "removeAll",
-          "printedName": "removeAll(keepingCapacity:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV9removeAll15keepingCapacityySb_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "hasDefaultArg": true,
-              "usr": "s:Sb"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s15ContiguousArrayV12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15ContiguousArrayV12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "description",
-          "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:s15ContiguousArrayV11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15ContiguousArrayV11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "debugDescription",
-          "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s15ContiguousArrayV16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15ContiguousArrayV16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeBufferPointer",
-          "printedName": "withUnsafeBufferPointer(_:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV23withUnsafeBufferPointeryqd__qd__SRyxGKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafeBufferPointer<ContiguousArray<Element>.Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeBufferPointer<ContiguousArray<Element>.Element>)",
-                  "usr": "s:SR",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeBufferPointer",
-                      "printedName": "UnsafeBufferPointer<ContiguousArray<Element>.Element>",
-                      "usr": "s:SR",
-                      "children": [
-                        {
-                          "kind": "TypeNameAlias",
-                          "name": "Element",
-                          "printedName": "ContiguousArray<Element>.Element",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GenericTypeParam",
-                              "printedName": "τ_0_0"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeMutableBufferPointer",
-          "printedName": "withUnsafeMutableBufferPointer(_:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV30withUnsafeMutableBufferPointeryqd__qd__SryxGzKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inline",
-            "Semantics"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(inout UnsafeMutableBufferPointer<ContiguousArray<Element>.Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(inout UnsafeMutableBufferPointer<ContiguousArray<Element>.Element>)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "InOut",
-                      "printedName": "inout UnsafeMutableBufferPointer<ContiguousArray<Element>.Element>"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "replaceSubrange",
-          "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV15replaceSubrange_4withySnySiG_qd__t7ElementQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, C where Element == C.Element, C : Collection>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Int>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "C"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "hash",
-          "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayVsSHRzlE4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Hasher",
-              "printedName": "Hasher",
-              "usr": "s:s6HasherV"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "hashValue",
-          "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s15ContiguousArrayVsSHRzlE9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15ContiguousArrayVsSHRzlE9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeMutableBytes",
-          "printedName": "withUnsafeMutableBytes(_:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV22withUnsafeMutableBytesyqd__qd__SwKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafeMutableRawBufferPointer) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeMutableRawBufferPointer)",
-                  "usr": "s:Sw",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeMutableRawBufferPointer",
-                      "printedName": "UnsafeMutableRawBufferPointer",
-                      "usr": "s:Sw"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeBytes",
-          "printedName": "withUnsafeBytes(_:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV15withUnsafeBytesyqd__qd__SWKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafeRawBufferPointer) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeRawBufferPointer)",
-                  "usr": "s:SW",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeRawBufferPointer",
-                      "printedName": "UnsafeRawBufferPointer",
-                      "usr": "s:SW"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        }
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "ClosedRange",
       "printedName": "ClosedRange",
-      "declKind": "Struct",
-      "usr": "s:SN",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Bound where Bound : Comparable>",
-      "conformingProtocols": [
-        "RangeExpression",
-        "Sequence",
-        "Collection",
-        "BidirectionalCollection",
-        "RandomAccessCollection",
-        "Equatable",
-        "Hashable",
-        "CustomStringConvertible",
-        "CustomDebugStringConvertible",
-        "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "lowerBound",
           "printedName": "lowerBound",
-          "declKind": "Var",
-          "usr": "s:SN10lowerBoundxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Bound"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SN10lowerBoundxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Bound"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SN10lowerBoundxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SN10lowerBoundxvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Var",
           "name": "upperBound",
           "printedName": "upperBound",
-          "declKind": "Var",
-          "usr": "s:SN10upperBoundxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Bound"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SN10upperBoundxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Bound"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SN10upperBoundxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SN10upperBoundxvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(uncheckedBounds:)",
-          "declKind": "Constructor",
-          "usr": "s:SN15uncheckedBoundsSNyxGx5lower_x5uppert_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ClosedRange",
-              "printedName": "ClosedRange<Bound>",
-              "usr": "s:SN",
+              "printedName": "ClosedRange<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Bound"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:SN"
             },
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(lower: ClosedRange<Bound>.Bound, upper: ClosedRange<Bound>.Bound)",
+              "printedName": "(lower: τ_0_0, upper: τ_0_0)",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Bound",
-                  "printedName": "ClosedRange<Bound>.Bound",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Bound",
-                  "printedName": "ClosedRange<Bound>.Bound",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SN15uncheckedBoundsSNyxGx5lower_x5uppert_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "isEmpty",
           "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:SN7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -24670,11 +24453,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SN7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -24682,55 +24460,56 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SN7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Comparable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SN7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "relative",
           "printedName": "relative(to:)",
-          "declKind": "Func",
-          "usr": "s:SN8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound, C where Bound == C.Index, C : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
-              "printedName": "Range<Bound>",
-              "usr": "s:Sn",
+              "printedName": "Range<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Bound"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "C"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SN8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Index, τ_1_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:SN8containsySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -24741,214 +24520,178 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Bound"
+              "printedName": "τ_0_0"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Bound",
-          "printedName": "Bound",
-          "declKind": "TypeAlias",
-          "usr": "s:SN5Bounda",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:SN8containsySbxF",
           "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "IndexingIterator",
-              "printedName": "IndexingIterator<ClosedRange<Bound>>",
-              "usr": "s:s16IndexingIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "ClosedRange",
-                  "printedName": "ClosedRange<Bound>",
-                  "usr": "s:SN",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Bound"
-                    }
-                  ]
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "Enum",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "conformingProtocols": [
-            "Comparable",
-            "Equatable",
-            "Hashable"
-          ],
-          "declAttributes": [
-            "Frozen"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "pastEnd",
               "printedName": "pastEnd",
-              "declKind": "EnumElement",
-              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO7pastEndyADyx_GAFmSxRzSZABRQlF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
                   "name": "GenericFunction",
-                  "printedName": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger> (ClosedRange<Bound>.Index.Type) -> ClosedRange<Bound>.Index",
+                  "printedName": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger> (ClosedRange<τ_0_0>.Index.Type) -> ClosedRange<τ_0_0>.Index",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Index",
-                      "printedName": "ClosedRange<Bound>.Index",
+                      "printedName": "ClosedRange<τ_0_0>.Index",
                       "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(ClosedRange<Bound>.Index.Type)",
+                      "name": "Metatype",
+                      "printedName": "ClosedRange<τ_0_0>.Index.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "ClosedRange<Bound>.Index.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Index",
-                              "printedName": "ClosedRange<Bound>.Index",
-                              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
-                            }
-                          ]
+                          "name": "Index",
+                          "printedName": "ClosedRange<τ_0_0>.Index",
+                          "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO7pastEndyADyx_GAFmSxRzSZABRQlF",
+              "moduleName": "Swift",
+              "fixedbinaryorder": 0
             },
             {
               "kind": "Var",
               "name": "inRange",
               "printedName": "inRange",
-              "declKind": "EnumElement",
-              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO7inRangeyADyx_GxcAFmSxRzSZABRQlF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
                   "name": "GenericFunction",
-                  "printedName": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger> (ClosedRange<Bound>.Index.Type) -> (Bound) -> ClosedRange<Bound>.Index",
+                  "printedName": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger> (ClosedRange<τ_0_0>.Index.Type) -> (τ_0_0) -> ClosedRange<τ_0_0>.Index",
                   "children": [
                     {
                       "kind": "TypeFunc",
                       "name": "Function",
-                      "printedName": "(Bound) -> ClosedRange<Bound>.Index",
+                      "printedName": "(τ_0_0) -> ClosedRange<τ_0_0>.Index",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "Index",
-                          "printedName": "ClosedRange<Bound>.Index",
+                          "printedName": "ClosedRange<τ_0_0>.Index",
                           "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
                         },
                         {
                           "kind": "TypeNominal",
-                          "name": "Paren",
-                          "printedName": "(Bound)",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GenericTypeParam",
-                              "printedName": "Bound"
-                            }
-                          ]
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
                         }
                       ]
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(ClosedRange<Bound>.Index.Type)",
+                      "name": "Metatype",
+                      "printedName": "ClosedRange<τ_0_0>.Index.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "ClosedRange<Bound>.Index.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Index",
-                              "printedName": "ClosedRange<Bound>.Index",
-                              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
-                            }
-                          ]
+                          "name": "Index",
+                          "printedName": "ClosedRange<τ_0_0>.Index",
+                          "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
                         }
                       ]
                     }
                   ]
                 }
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO7inRangeyADyx_GxcAFmSxRzSZABRQlF",
+              "moduleName": "Swift",
+              "fixedbinaryorder": 1
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ClosedRange<τ_0_0>.Index",
+                  "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ClosedRange<τ_0_0>.Index",
+                  "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO2eeoiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ClosedRange<τ_0_0>.Index",
+                  "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ClosedRange<τ_0_0>.Index",
+                  "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO1loiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexOsSHRzrlE4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Hashable, Bound : Strideable, Bound.Stride : SignedInteger>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -24961,16 +24704,19 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexOsSHRzrlE4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable, τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexOsSHRzrlE9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -24982,11 +24728,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexOsSHRzrlE9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Bound where Bound : Hashable, Bound : Strideable, Bound.Stride : SignedInteger>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -24994,198 +24735,172 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexOsSHRzrlE9hashValueSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Hashable, τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexOsSHRzrlE9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE11SubSequencea",
-          "location": "",
+          ],
+          "declKind": "Enum",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO",
           "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<ClosedRange<Bound>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "ClosedRange",
-                  "printedName": "ClosedRange<Bound>",
-                  "usr": "s:SN",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Bound"
-                    }
-                  ]
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "declAttributes": [
+            "Frozen"
+          ],
+          "conformingProtocols": [
+            "Comparable",
+            "Equatable",
+            "Hashable"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE10startIndexSNsSxRzSZABRQrlE0C0Oyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ClosedRange<Bound>.Index",
+              "printedName": "ClosedRange<τ_0_0>.Index",
               "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SNsSxRzSZ6StrideRpzrlE10startIndexSNsSxRzSZABRQrlE0C0Oyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "ClosedRange<Bound>.Index",
+                  "printedName": "ClosedRange<τ_0_0>.Index",
                   "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE10startIndexSNsSxRzSZABRQrlE0C0Oyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE10startIndexSNsSxRzSZABRQrlE0C0Oyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE8endIndexSNsSxRzSZABRQrlE0C0Oyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ClosedRange<Bound>.Index",
+              "printedName": "ClosedRange<τ_0_0>.Index",
               "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SNsSxRzSZ6StrideRpzrlE8endIndexSNsSxRzSZABRQrlE0C0Oyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "ClosedRange<Bound>.Index",
+                  "printedName": "ClosedRange<τ_0_0>.Index",
                   "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE8endIndexSNsSxRzSZABRQrlE0C0Oyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE8endIndexSNsSxRzSZABRQrlE0C0Oyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE5index5afterSNsSxRzSZABRQrlE5IndexOyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ClosedRange<Bound>.Index",
+              "printedName": "ClosedRange<τ_0_0>.Index",
               "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ClosedRange<Bound>.Index",
+              "printedName": "ClosedRange<τ_0_0>.Index",
               "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE5index5afterSNsSxRzSZABRQrlE5IndexOyx_GAG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE5index6beforeSNsSxRzSZABRQrlE5IndexOyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ClosedRange<Bound>.Index",
+              "printedName": "ClosedRange<τ_0_0>.Index",
               "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ClosedRange<Bound>.Index",
+              "printedName": "ClosedRange<τ_0_0>.Index",
               "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE5index6beforeSNsSxRzSZABRQrlE5IndexOyx_GAG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE5index_8offsetBySNsSxRzSZABRQrlE5IndexOyx_GAG_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ClosedRange<Bound>.Index",
+              "printedName": "ClosedRange<τ_0_0>.Index",
               "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ClosedRange<Bound>.Index",
+              "printedName": "ClosedRange<τ_0_0>.Index",
               "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
             },
             {
@@ -25194,20 +24909,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE5index_8offsetBySNsSxRzSZABRQrlE5IndexOyx_GAG_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE8distance4from2toSiSNsSxRzSZABRQrlE5IndexOyx_G_AHtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -25218,62 +24932,149 @@
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ClosedRange<Bound>.Index",
+              "printedName": "ClosedRange<τ_0_0>.Index",
               "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ClosedRange<Bound>.Index",
+              "printedName": "ClosedRange<τ_0_0>.Index",
               "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE8distance4from2toSiSNsSxRzSZABRQrlE5IndexOyx_G_AHtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "DefaultIndices",
-              "printedName": "DefaultIndices<ClosedRange<Bound>>",
-              "usr": "s:SI",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "ClosedRange<τ_0_0>.Index",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlEyxSNsSxRzSZABRQrlE5IndexOyx_Gcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<ClosedRange<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ClosedRange",
-                  "printedName": "ClosedRange<Bound>",
-                  "usr": "s:SN",
+                  "printedName": "ClosedRange<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Bound"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:SN"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<ClosedRange<τ_0_0>.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ClosedRange<τ_0_0>.Index",
+                  "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
+                }
+              ],
+              "usr": "s:Sn"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlEys5SliceVySNyxGGSnySNsSxRzSZABRQrlE5IndexOyx_GGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SN"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SN"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SN2eeoiySbSNyxG_ABtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SNsSHRzrlE4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable, Bound : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -25286,16 +25087,19 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SNsSHRzrlE4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable, τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SNsSHRzrlE9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -25307,11 +25111,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SNsSHRzrlE9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable, Bound : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -25319,21 +25118,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SNsSHRzrlE9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Comparable, τ_0_0 : Hashable>",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SNsSHRzrlE9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:SN11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -25345,11 +25146,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SN11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -25357,18 +25153,24 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SN11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Comparable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SN11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:SN16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -25380,11 +25182,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SN16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -25392,18 +25189,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SN16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Comparable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SN16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:SN12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -25415,11 +25215,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SN12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -25427,150 +25222,132 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SN12customMirrors0B0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Comparable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SN12customMirrors0B0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "clamped",
           "printedName": "clamped(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SN"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SN"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SN7clamped2toSNyxGAC_tF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
           "declAttributes": [
             "Inline",
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ClosedRange",
-              "printedName": "ClosedRange<Bound>",
-              "usr": "s:SN",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "ClosedRange",
-              "printedName": "ClosedRange<Bound>",
-              "usr": "s:SN",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SN"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SNsSxRzSZ6StrideRpzrlEySNyxGSnyxGcfc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>"
+        },
+        {
+          "kind": "Function",
+          "name": "overlaps",
+          "printedName": "overlaps(_:)",
           "children": [
             {
               "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
               "name": "ClosedRange",
-              "printedName": "ClosedRange<Bound>",
-              "usr": "s:SN",
+              "printedName": "ClosedRange<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Bound"
+                  "printedName": "τ_0_0"
                 }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<ClosedRange<Bound>.Bound>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Bound",
-                  "printedName": "ClosedRange<Bound>.Bound",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
+              ],
+              "usr": "s:SN"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "overlaps",
-          "printedName": "overlaps(_:)",
+          ],
           "declKind": "Func",
           "usr": "s:SN8overlapsySbSNyxGF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "ClosedRange",
-              "printedName": "ClosedRange<ClosedRange<Bound>.Bound>",
-              "usr": "s:SN",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Bound",
-                  "printedName": "ClosedRange<Bound>.Bound",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
           ]
         },
         {
           "kind": "Function",
           "name": "overlaps",
           "printedName": "overlaps(_:)",
-          "declKind": "Func",
-          "usr": "s:SN8overlapsySbSnyxGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -25581,436 +25358,137 @@
             {
               "kind": "TypeNominal",
               "name": "Range",
-              "printedName": "Range<ClosedRange<Bound>.Bound>",
-              "usr": "s:Sn",
+              "printedName": "Range<τ_0_0>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Bound",
-                  "printedName": "ClosedRange<Bound>.Bound",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SN8overlapsySbSnyxGF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlEySNyxGACcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ClosedRange",
-              "printedName": "ClosedRange<Bound>",
-              "usr": "s:SN",
+              "printedName": "ClosedRange<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Bound"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:SN"
             },
             {
               "kind": "TypeNominal",
               "name": "ClosedRange",
-              "printedName": "ClosedRange<ClosedRange<Bound>.Bound>",
-              "usr": "s:SN",
+              "printedName": "ClosedRange<τ_0_0>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Bound",
-                  "printedName": "ClosedRange<Bound>.Bound",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:SN"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlEySNyxGACcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CountableClosedRange",
-      "printedName": "CountableClosedRange",
-      "declKind": "TypeAlias",
-      "usr": "s:s20CountableClosedRangea",
-      "location": "",
+      ],
+      "declKind": "Struct",
+      "usr": "s:SN",
       "moduleName": "Swift",
-      "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ClosedRange",
-          "printedName": "ClosedRange<Bound>",
-          "usr": "s:SN",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CChar",
-      "printedName": "CChar",
-      "declKind": "TypeAlias",
-      "usr": "s:s5CChara",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Int8",
-          "printedName": "Int8",
-          "usr": "s:s4Int8V"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CUnsignedChar",
-      "printedName": "CUnsignedChar",
-      "declKind": "TypeAlias",
-      "usr": "s:s13CUnsignedChara",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "UInt8",
-          "printedName": "UInt8",
-          "usr": "s:s5UInt8V"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CUnsignedShort",
-      "printedName": "CUnsignedShort",
-      "declKind": "TypeAlias",
-      "usr": "s:s14CUnsignedShorta",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "UInt16",
-          "printedName": "UInt16",
-          "usr": "s:s6UInt16V"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CUnsignedInt",
-      "printedName": "CUnsignedInt",
-      "declKind": "TypeAlias",
-      "usr": "s:s12CUnsignedInta",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "UInt32",
-          "printedName": "UInt32",
-          "usr": "s:s6UInt32V"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CUnsignedLong",
-      "printedName": "CUnsignedLong",
-      "declKind": "TypeAlias",
-      "usr": "s:s13CUnsignedLonga",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "UInt",
-          "printedName": "UInt",
-          "usr": "s:Su"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CUnsignedLongLong",
-      "printedName": "CUnsignedLongLong",
-      "declKind": "TypeAlias",
-      "usr": "s:s013CUnsignedLongB0a",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "UInt64",
-          "printedName": "UInt64",
-          "usr": "s:s6UInt64V"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CSignedChar",
-      "printedName": "CSignedChar",
-      "declKind": "TypeAlias",
-      "usr": "s:s11CSignedChara",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Int8",
-          "printedName": "Int8",
-          "usr": "s:s4Int8V"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CShort",
-      "printedName": "CShort",
-      "declKind": "TypeAlias",
-      "usr": "s:s6CShorta",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Int16",
-          "printedName": "Int16",
-          "usr": "s:s5Int16V"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CInt",
-      "printedName": "CInt",
-      "declKind": "TypeAlias",
-      "usr": "s:s4CInta",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Int32",
-          "printedName": "Int32",
-          "usr": "s:s5Int32V"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CLong",
-      "printedName": "CLong",
-      "declKind": "TypeAlias",
-      "usr": "s:s5CLonga",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Int",
-          "printedName": "Int",
-          "usr": "s:Si"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CLongLong",
-      "printedName": "CLongLong",
-      "declKind": "TypeAlias",
-      "usr": "s:s9CLongLonga",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Int64",
-          "printedName": "Int64",
-          "usr": "s:s5Int64V"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CFloat",
-      "printedName": "CFloat",
-      "declKind": "TypeAlias",
-      "usr": "s:s6CFloata",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Float",
-          "printedName": "Float",
-          "usr": "s:Sf"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CDouble",
-      "printedName": "CDouble",
-      "declKind": "TypeAlias",
-      "usr": "s:s7CDoublea",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Double",
-          "printedName": "Double",
-          "usr": "s:Sd"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CLongDouble",
-      "printedName": "CLongDouble",
-      "declKind": "TypeAlias",
-      "usr": "s:s11CLongDoublea",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Float80",
-          "printedName": "Float80",
-          "usr": "s:s7Float80V"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CWideChar",
-      "printedName": "CWideChar",
-      "declKind": "TypeAlias",
-      "usr": "s:s9CWideChara",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Scalar",
-          "printedName": "Unicode.Scalar",
-          "usr": "s:s7UnicodeO6ScalarV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CChar16",
-      "printedName": "CChar16",
-      "declKind": "TypeAlias",
-      "usr": "s:s7CChar16a",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "UInt16",
-          "printedName": "UInt16",
-          "usr": "s:s6UInt16V"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CChar32",
-      "printedName": "CChar32",
-      "declKind": "TypeAlias",
-      "usr": "s:s7CChar32a",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Scalar",
-          "printedName": "Unicode.Scalar",
-          "usr": "s:s7UnicodeO6ScalarV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CBool",
-      "printedName": "CBool",
-      "declKind": "TypeAlias",
-      "usr": "s:s5CBoola",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Bool",
-          "printedName": "Bool",
-          "usr": "s:Sb"
-        }
+      "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "RangeExpression",
+        "Sequence",
+        "Collection",
+        "BidirectionalCollection",
+        "RandomAccessCollection",
+        "Equatable",
+        "Hashable",
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible",
+        "CustomReflectable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "OpaquePointer",
       "printedName": "OpaquePointer",
-      "declKind": "Struct",
-      "usr": "s:s13OpaquePointerV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable",
-        "CustomDebugStringConvertible",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
+          "kind": "Var",
+          "name": "_rawValue",
+          "printedName": "_rawValue",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "BuiltinRawPointer",
+              "printedName": "Builtin.RawPointer"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinRawPointer",
+                  "printedName": "Builtin.RawPointer"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13OpaquePointerV9_rawValueBpvg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13OpaquePointerV9_rawValueBpvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABBpcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "UsableFromInline"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -26019,36 +25497,29 @@
               "usr": "s:s13OpaquePointerV"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "RawPointer",
-              "printedName": "RawPointer",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "BuiltinRawPointer",
-                  "printedName": "Builtin.RawPointer"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "BuiltinRawPointer",
+              "printedName": "Builtin.RawPointer"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABBpcfc",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "Transparent",
+            "UsableFromInline"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerV10bitPatternABSgSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "OpaquePointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<OpaquePointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26056,7 +25527,8 @@
                   "printedName": "OpaquePointer",
                   "usr": "s:s13OpaquePointerV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -26064,25 +25536,23 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerV10bitPatternABSgSi_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerV10bitPatternABSgSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "OpaquePointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<OpaquePointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26090,7 +25560,8 @@
                   "printedName": "OpaquePointer",
                   "usr": "s:s13OpaquePointerV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -26098,20 +25569,18 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerV10bitPatternABSgSu_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABSPyxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -26122,36 +25591,34 @@
             {
               "kind": "TypeNominal",
               "name": "UnsafePointer",
-              "printedName": "UnsafePointer<T>",
-              "usr": "s:SP",
+              "printedName": "UnsafePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABSPyxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABSgSPyxGSgclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "OpaquePointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<OpaquePointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26159,43 +25626,43 @@
                   "printedName": "OpaquePointer",
                   "usr": "s:s13OpaquePointerV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafePointer<T>?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafePointer<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafePointer",
-                  "printedName": "UnsafePointer<T>",
-                  "usr": "s:SP",
+                  "printedName": "UnsafePointer<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "T"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABSgSPyxGSgclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABSpyxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -26206,36 +25673,34 @@
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
-              "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
+              "printedName": "UnsafeMutablePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABSpyxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABSgSpyxGSgclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "OpaquePointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<OpaquePointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26243,42 +25708,75 @@
                   "printedName": "OpaquePointer",
                   "usr": "s:s13OpaquePointerV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafeMutablePointer<T>?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafeMutablePointer<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafeMutablePointer",
-                  "printedName": "UnsafeMutablePointer<T>",
-                  "usr": "s:Sp",
+                  "printedName": "UnsafeMutablePointer<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "T"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABSgSpyxGSgclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "OpaquePointer",
+              "printedName": "OpaquePointer",
+              "usr": "s:s13OpaquePointerV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "OpaquePointer",
+              "printedName": "OpaquePointer",
+              "usr": "s:s13OpaquePointerV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13OpaquePointerV2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s13OpaquePointerV4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -26291,16 +25789,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13OpaquePointerV4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s13OpaquePointerV9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -26312,10 +25812,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13OpaquePointerV9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26323,18 +25819,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13OpaquePointerV9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s13OpaquePointerV9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s13OpaquePointerV16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -26346,10 +25846,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13OpaquePointerV16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26357,21 +25853,20 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13OpaquePointerV16debugDescriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s13OpaquePointerV16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABSvcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -26385,25 +25880,23 @@
               "printedName": "UnsafeMutableRawPointer",
               "usr": "s:Sv"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABSvcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABSgSvSgcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "OpaquePointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<OpaquePointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26411,13 +25904,13 @@
                   "printedName": "OpaquePointer",
                   "usr": "s:s13OpaquePointerV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafeMutableRawPointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafeMutableRawPointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26425,21 +25918,21 @@
                   "printedName": "UnsafeMutableRawPointer",
                   "usr": "s:Sv"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABSgSvSgcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABSVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -26453,25 +25946,23 @@
               "printedName": "UnsafeRawPointer",
               "usr": "s:SV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABSVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABSgSVSgcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "OpaquePointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<OpaquePointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26479,13 +25970,13 @@
                   "printedName": "OpaquePointer",
                   "usr": "s:s13OpaquePointerV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafeRawPointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafeRawPointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26493,35 +25984,83 @@
                   "printedName": "UnsafeRawPointer",
                   "usr": "s:SV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABSgSVSgcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s13OpaquePointerV",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable",
+        "CustomDebugStringConvertible",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "CVaListPointer",
       "printedName": "CVaListPointer",
-      "declKind": "Struct",
-      "usr": "s:s14CVaListPointerV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "CustomDebugStringConvertible"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
+          "name": "value",
+          "printedName": "value",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutableRawPointer",
+              "printedName": "UnsafeMutableRawPointer",
+              "usr": "s:Sv"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutableRawPointer",
+                  "printedName": "UnsafeMutableRawPointer",
+                  "usr": "s:Sv"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14CVaListPointerV5valueSvvg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14CVaListPointerV5valueSvvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s14CVaListPointerV16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -26533,10 +26072,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14CVaListPointerV16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26544,130 +26079,130 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14CVaListPointerV16debugDescriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s14CVaListPointerV16debugDescriptionSSvp",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s14CVaListPointerV",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "CustomDebugStringConvertible"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Dictionary",
       "printedName": "Dictionary",
-      "declKind": "Struct",
-      "usr": "s:SD",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Key, Value where Key : Hashable>",
-      "conformingProtocols": [
-        "Encodable",
-        "Decodable",
-        "Sequence",
-        "Collection",
-        "ExpressibleByDictionaryLiteral",
-        "Equatable",
-        "Hashable",
-        "_HasCustomAnyHashableRepresentation",
-        "CustomStringConvertible",
-        "CustomDebugStringConvertible",
-        "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:SD7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
+          "kind": "Var",
+          "name": "_variant",
+          "printedName": "_variant",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(key: Key, value: Value)",
+              "name": "_Variant",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>._Variant",
+              "usr": "s:SD8_VariantO"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Key"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
+                  "name": "_Variant",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>._Variant",
+                  "usr": "s:SD8_VariantO"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD8_variantSD8_VariantOyxq__Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SD8_variantSD8_VariantOyxq__Gvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:S2Dyxq_Gycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Dictionary",
-              "printedName": "Dictionary<Key, Value>",
-              "usr": "s:SD",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Key"
+                  "printedName": "τ_0_0"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Value"
+                  "printedName": "τ_0_1"
                 }
-              ]
+              ],
+              "usr": "s:SD"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:S2Dyxq_Gycfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(minimumCapacity:)",
-          "declKind": "Constructor",
-          "usr": "s:SD15minimumCapacitySDyxq_GSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Dictionary",
-              "printedName": "Dictionary<Key, Value>",
-              "usr": "s:SD",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Key"
+                  "printedName": "τ_0_0"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Value"
+                  "printedName": "τ_0_1"
                 }
-              ]
+              ],
+              "usr": "s:SD"
             },
             {
               "kind": "TypeNominal",
@@ -26675,226 +26210,183 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SD15minimumCapacitySDyxq_GSi_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(uniqueKeysWithValues:)",
-          "declKind": "Constructor",
-          "usr": "s:SD20uniqueKeysWithValuesSDyxq_Gqd___tcSTRd__x_q_t7ElementRtd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value, S where Key : Hashable, S : Sequence, S.Element == (Key, Value)>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Dictionary",
-              "printedName": "Dictionary<Key, Value>",
-              "usr": "s:SD",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Key"
+                  "printedName": "τ_0_0"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Value"
+                  "printedName": "τ_0_1"
                 }
-              ]
+              ],
+              "usr": "s:SD"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "S"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SD20uniqueKeysWithValuesSDyxq_Gqd__n_tcSTRd__x_q_t7ElementRtd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1, τ_1_0 where τ_0_0 : Hashable, τ_1_0 : Sequence, τ_1_0.Element == (τ_0_0, τ_0_1)>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:uniquingKeysWith:)",
-          "declKind": "Constructor",
-          "usr": "s:SD_16uniquingKeysWithSDyxq_Gqd___q_q__q_tKXEtKcSTRd__x_q_t7ElementRtd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value, S where Key : Hashable, S : Sequence, S.Element == (Key, Value)>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Dictionary",
-              "printedName": "Dictionary<Key, Value>",
-              "usr": "s:SD",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Key"
+                  "printedName": "τ_0_0"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Value"
+                  "printedName": "τ_0_1"
                 }
-              ]
+              ],
+              "usr": "s:SD"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "S"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value) throws -> Dictionary<Key, Value>.Value",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_1, τ_0_1) throws -> τ_0_1",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(τ_0_1, τ_0_1)",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "τ_0_1"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
                     }
                   ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    }
-                  ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SD_16uniquingKeysWithSDyxq_Gqd__n_q_q__q_tKXEtKcSTRd__x_q_t7ElementRtd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1, τ_1_0 where τ_0_0 : Hashable, τ_1_0 : Sequence, τ_1_0.Element == (τ_0_0, τ_0_1)>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(grouping:by:)",
-          "declKind": "Constructor",
-          "usr": "s:SD8grouping2bySDyxSay7ElementQyd__GGqd___xADKXEtKcAERs_STRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value, S where Key : Hashable, Value == [S.Element], S : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Dictionary",
-              "printedName": "Dictionary<Key, Value>",
-              "usr": "s:SD",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Key"
+                  "printedName": "τ_0_0"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Value"
+                  "printedName": "τ_0_1"
                 }
-              ]
+              ],
+              "usr": "s:SD"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "S"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(S.Element) throws -> Dictionary<Key, Value>.Key",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_1_0.Element) throws -> τ_0_0",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Key",
-                  "printedName": "Dictionary<Key, Value>.Key",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(S.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "S.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_1_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SD8grouping2bySDyxSay7ElementQyd__GGqd__n_xADKXEtKcAERs_STRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1, τ_1_0 where τ_0_0 : Hashable, τ_0_1 == Array<τ_1_0.Element>, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:SDsSERzSER_rlE6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Encodable, Key : Hashable, Value : Encodable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -26907,39 +26399,35 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SDsSERzSER_rlE6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Encodable, τ_0_0 : Hashable, τ_0_1 : Encodable>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:SDsSeRzSeR_rlE4fromSDyxq_Gs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Decodable, Key : Hashable, Value : Decodable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Dictionary",
-              "printedName": "Dictionary<Key, Value>",
-              "usr": "s:SD",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Key"
+                  "printedName": "τ_0_0"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Value"
+                  "printedName": "τ_0_1"
                 }
-              ]
+              ],
+              "usr": "s:SD"
             },
             {
               "kind": "TypeNominal",
@@ -26947,45 +26435,78 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SDsSeRzSeR_rlE4fromSDyxq_Gs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Decodable, τ_0_0 : Hashable, τ_0_1 : Decodable>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:SD12makeIterators010DictionaryB0Vyxq_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "DictionaryIterator",
-              "printedName": "DictionaryIterator<Dictionary<Key, Value>.Key, Dictionary<Key, Value>.Value>",
-              "usr": "s:s18DictionaryIteratorV",
+              "name": "Iterator",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>.Iterator",
+              "usr": "s:SD8IteratorV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD12makeIteratorSD0B0Vyxq__GyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "filter",
+          "printedName": "filter(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Key",
-                  "printedName": "Dictionary<Key, Value>.Key",
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:SD"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "((key: τ_0_0, value: τ_0_1)) throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(key: τ_0_0, value: τ_0_1)",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "τ_0_0"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
+                    },
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
@@ -26993,166 +26514,221 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SD6filterySDyxq_GSbx3key_q_5valuet_tKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Rethrows",
+            "Available",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:SD10startIndexSD0B0Vyxq__Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "Dictionary<Key, Value>.Index",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
               "usr": "s:SD5IndexV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD10startIndexSD0B0Vyxq__Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
                   "usr": "s:SD5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD10startIndexSD0B0Vyxq__Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD10startIndexSD0B0Vyxq__Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:SD8endIndexSD0B0Vyxq__Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "Dictionary<Key, Value>.Index",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
               "usr": "s:SD5IndexV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD8endIndexSD0B0Vyxq__Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
                   "usr": "s:SD5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD8endIndexSD0B0Vyxq__Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD8endIndexSD0B0Vyxq__Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:SD5index5afterSD5IndexVyxq__GAE_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "Dictionary<Key, Value>.Index",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
               "usr": "s:SD5IndexV"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "Dictionary<Key, Value>.Index",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
               "usr": "s:SD5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD5index5afterSD5IndexVyxq__GAE_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+              "usr": "s:SD5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD9formIndex5afterySD0B0Vyxq__Gz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(forKey:)",
-          "declKind": "Func",
-          "usr": "s:SD5index6forKeySD5IndexVyxq__GSgx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Dictionary<Key, Value>.Index?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Dictionary<τ_0_0, τ_0_1>.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
                   "usr": "s:SD5IndexV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "Dictionary<Key, Value>.Key",
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD5index6forKeySD5IndexVyxq__GSgx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(key: τ_0_0, value: τ_0_1)",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
                 }
               ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+              "usr": "s:SD5IndexV"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SDyx3key_q_5valuetSD5IndexVyxq__Gcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:SD5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -27164,11 +26740,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -27176,21 +26747,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "isEmpty",
           "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:SD7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -27202,11 +26776,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -27214,879 +26783,29 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:SD8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DictionaryIterator",
-              "printedName": "DictionaryIterator<Key, Value>",
-              "usr": "s:s18DictionaryIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Key"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:SD11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<Dictionary<Key, Value>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Dictionary",
-                  "printedName": "Dictionary<Key, Value>",
-                  "usr": "s:SD",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:SD7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DefaultIndices",
-              "printedName": "DefaultIndices<Dictionary<Key, Value>>",
-              "usr": "s:SI",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Dictionary",
-                  "printedName": "Dictionary<Key, Value>",
-                  "usr": "s:SD",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(dictionaryLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:SD17dictionaryLiteralSDyxq_Gx_q_td_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "declAttributes": [
-            "Effects",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Dictionary",
-              "printedName": "Dictionary<Key, Value>",
-              "usr": "s:SD",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Key"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "[(Key, Value)]",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(Key, Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Key",
-          "printedName": "Key",
-          "declKind": "TypeAlias",
-          "usr": "s:SD3Keya",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Key"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Value",
-          "printedName": "Value",
-          "declKind": "TypeAlias",
-          "usr": "s:SD5Valuea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Value"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "mapValues",
-          "printedName": "mapValues(_:)",
-          "declKind": "Func",
-          "usr": "s:SD9mapValuesySDyxqd__Gqd__q_KXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value, T where Key : Hashable>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Dictionary",
-              "printedName": "Dictionary<Dictionary<Key, Value>.Key, T>",
-              "usr": "s:SD",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Key",
-                  "printedName": "Dictionary<Key, Value>.Key",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Dictionary<Key, Value>.Value) throws -> T",
-              "typeAttributes": [
-                "noescape"
               ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Dictionary<Key, Value>.Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
+              "declKind": "Accessor",
+              "usr": "s:SD7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "Function",
-          "name": "compactMapValues",
-          "printedName": "compactMapValues(_:)",
-          "declKind": "Func",
-          "usr": "s:SD16compactMapValuesySDyxqd__Gqd__Sgq_KXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value, T where Key : Hashable>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Dictionary",
-              "printedName": "Dictionary<Dictionary<Key, Value>.Key, T>",
-              "usr": "s:SD",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Key",
-                  "printedName": "Dictionary<Key, Value>.Key",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Dictionary<Key, Value>.Value) throws -> T?",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "T?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "T"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Dictionary<Key, Value>.Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "updateValue",
-          "printedName": "updateValue(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:SD11updateValue_6forKeyq_Sgq__xtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
+          "kind": "Var",
+          "name": "first",
+          "printedName": "first",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Dictionary<Key, Value>.Value?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Value",
-              "printedName": "Dictionary<Key, Value>.Value",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_1"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "Dictionary<Key, Value>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "merge",
-          "printedName": "merge(_:uniquingKeysWith:)",
-          "declKind": "Func",
-          "usr": "s:SD5merge_16uniquingKeysWithyqd___q_q__q_tKXEtKSTRd__x_q_t7ElementRtd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value, S where Key : Hashable, S : Sequence, S.Element == (Key, Value)>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value) throws -> Dictionary<Key, Value>.Value",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "merge",
-          "printedName": "merge(_:uniquingKeysWith:)",
-          "declKind": "Func",
-          "usr": "s:SD5merge_16uniquingKeysWithySDyxq_G_q_q__q_tKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Dictionary",
-              "printedName": "[Dictionary<Key, Value>.Key : Dictionary<Key, Value>.Value]",
-              "usr": "s:SD",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Key",
-                  "printedName": "Dictionary<Key, Value>.Key",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value) throws -> Dictionary<Key, Value>.Value",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "merging",
-          "printedName": "merging(_:uniquingKeysWith:)",
-          "declKind": "Func",
-          "usr": "s:SD7merging_16uniquingKeysWithSDyxq_Gqd___q_q__q_tKXEtKSTRd__x_q_t7ElementRtd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value, S where Key : Hashable, S : Sequence, S.Element == (Key, Value)>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Dictionary",
-              "printedName": "[Dictionary<Key, Value>.Key : Dictionary<Key, Value>.Value]",
-              "usr": "s:SD",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Key",
-                  "printedName": "Dictionary<Key, Value>.Key",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value) throws -> Dictionary<Key, Value>.Value",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "merging",
-          "printedName": "merging(_:uniquingKeysWith:)",
-          "declKind": "Func",
-          "usr": "s:SD7merging_16uniquingKeysWithSDyxq_GAC_q_q__q_tKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Dictionary",
-              "printedName": "[Dictionary<Key, Value>.Key : Dictionary<Key, Value>.Value]",
-              "usr": "s:SD",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Key",
-                  "printedName": "Dictionary<Key, Value>.Key",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Dictionary",
-              "printedName": "[Dictionary<Key, Value>.Key : Dictionary<Key, Value>.Value]",
-              "usr": "s:SD",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Key",
-                  "printedName": "Dictionary<Key, Value>.Key",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value) throws -> Dictionary<Key, Value>.Value",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "remove",
-          "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:SD6remove2atx3key_q_5valuetSD5IndexVyxq__G_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "Dictionary<Key, Value>.Element",
+              "printedName": "Optional<(key: τ_0_0, value: τ_0_1)>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -28105,78 +26824,707 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "Dictionary<Key, Value>.Index",
-              "usr": "s:SD5IndexV"
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<(key: τ_0_0, value: τ_0_1)>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Tuple",
+                      "printedName": "(key: τ_0_0, value: τ_0_1)",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_1"
+                        }
+                      ]
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD5firstx3key_q_5valuetSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD5firstx3key_q_5valuetSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "Function",
-          "name": "removeValue",
-          "printedName": "removeValue(forKey:)",
-          "declKind": "Func",
-          "usr": "s:SD11removeValue6forKeyq_Sgx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Dictionary<Key, Value>.Value?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_1>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SDyq_Sgxcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(dictionaryLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:SD"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<(τ_0_0, τ_0_1)>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(τ_0_0, τ_0_1)",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
                       "printedName": "τ_0_1"
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sa"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SD17dictionaryLiteralSDyxq_Gx_q_td_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Effects",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:default:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "Dictionary<Key, Value>.Key",
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "() -> τ_0_1",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SD_7defaultq_x_q_yXKtcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Function",
+          "name": "mapValues",
+          "printedName": "mapValues(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "Dictionary<τ_0_0, τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
                 }
+              ],
+              "usr": "s:SD"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_1) throws -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SD9mapValuesySDyxqd__Gqd__q_KXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1, τ_1_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "compactMapValues",
+          "printedName": "compactMapValues(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "Dictionary<τ_0_0, τ_1_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                }
+              ],
+              "usr": "s:SD"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_1) throws -> Optional<τ_1_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_1_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_1_0"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD16compactMapValuesySDyxqd__Gqd__Sgq_KXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1, τ_1_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "updateValue",
+          "printedName": "updateValue(_:forKey:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD11updateValue_6forKeyq_Sgq_n_xtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "merge",
+          "printedName": "merge(_:uniquingKeysWith:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_1, τ_0_1) throws -> τ_0_1",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(τ_0_1, τ_0_1)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD5merge_16uniquingKeysWithyqd__n_q_q__q_tKXEtKSTRd__x_q_t7ElementRtd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1, τ_1_0 where τ_0_0 : Hashable, τ_1_0 : Sequence, τ_1_0.Element == (τ_0_0, τ_0_1)>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "merge",
+          "printedName": "merge(_:uniquingKeysWith:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:SD"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_1, τ_0_1) throws -> τ_0_1",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(τ_0_1, τ_0_1)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD5merge_16uniquingKeysWithySDyxq_Gn_q_q__q_tKXEtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "merging",
+          "printedName": "merging(_:uniquingKeysWith:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:SD"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_1, τ_0_1) throws -> τ_0_1",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(τ_0_1, τ_0_1)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD7merging_16uniquingKeysWithSDyxq_Gqd__n_q_q__q_tKXEtKSTRd__x_q_t7ElementRtd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1, τ_1_0 where τ_0_0 : Hashable, τ_1_0 : Sequence, τ_1_0.Element == (τ_0_0, τ_0_1)>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "merging",
+          "printedName": "merging(_:uniquingKeysWith:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:SD"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:SD"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_1, τ_0_1) throws -> τ_0_1",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(τ_0_1, τ_0_1)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD7merging_16uniquingKeysWithSDyxq_GACn_q_q__q_tKXEtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "remove",
+          "printedName": "remove(at:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(key: τ_0_0, value: τ_0_1)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+              "usr": "s:SD5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD6remove2atx3key_q_5valuetSD5IndexVyxq__G_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "removeValue",
+          "printedName": "removeValue(forKey:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD11removeValue6forKeyq_Sgx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeAll",
           "printedName": "removeAll(keepingCapacity:)",
-          "declKind": "Func",
-          "usr": "s:SD9removeAll15keepingCapacityySb_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -28190,546 +27538,839 @@
               "hasDefaultArg": true,
               "usr": "s:Sb"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD9removeAll15keepingCapacityySb_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Var",
+          "name": "keys",
+          "printedName": "keys",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Keys",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>.Keys",
+              "usr": "s:SD4KeysV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Keys",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Keys",
+                  "usr": "s:SD4KeysV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD4keysSD4KeysVyxq__Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD4keysSD4KeysVyxq__Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Available",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "values",
+          "printedName": "values",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Values",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>.Values",
+              "usr": "s:SD6ValuesV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Values",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Values",
+                  "usr": "s:SD6ValuesV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD6valuesSD6ValuesVyxq__Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Values",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Values",
+                  "usr": "s:SD6ValuesV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD6valuesSD6ValuesVyxq__Gvs",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD6valuesSD6ValuesVyxq__Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Available",
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Keys",
           "printedName": "Keys",
+          "children": [
+            {
+              "kind": "Var",
+              "name": "_variant",
+              "printedName": "_variant",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_Variant",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>._Variant",
+                  "usr": "s:SD8_VariantO"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_Variant",
+                      "printedName": "Dictionary<τ_0_0, τ_0_1>._Variant",
+                      "usr": "s:SD8_VariantO"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD4KeysV8_variantSD8_VariantOyxq__Gvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD4KeysV8_variantSD8_VariantOyxq__Gvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "startIndex",
+              "printedName": "startIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+                  "usr": "s:SD5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+                      "usr": "s:SD5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD4KeysV10startIndexSD0C0Vyxq__Gvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD4KeysV10startIndexSD0C0Vyxq__Gvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "endIndex",
+              "printedName": "endIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+                  "usr": "s:SD5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+                      "usr": "s:SD5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD4KeysV8endIndexSD0C0Vyxq__Gvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD4KeysV8endIndexSD0C0Vyxq__Gvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+                  "usr": "s:SD5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD4KeysV5index5afterSD5IndexVyxq__GAG_tF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "formIndex",
+              "printedName": "formIndex(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD4KeysV9formIndex5afterySD0C0Vyxq__Gz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SD4KeysVyxSD5IndexVyxq__Gcip",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "count",
+              "printedName": "count",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD4KeysV5countSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD4KeysV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "isEmpty",
+              "printedName": "isEmpty",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD4KeysV7isEmptySbvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD4KeysV7isEmptySbvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Keys",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Keys",
+                  "usr": "s:SD4KeysV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Keys",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Keys",
+                  "usr": "s:SD4KeysV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD4KeysV2eeoiySbAByxq__G_ADtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "description",
+              "printedName": "description",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "String",
+                      "printedName": "String",
+                      "usr": "s:SS"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD4KeysV11descriptionSSvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD4KeysV11descriptionSSvp",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Var",
+              "name": "debugDescription",
+              "printedName": "debugDescription",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "String",
+                      "printedName": "String",
+                      "usr": "s:SS"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD4KeysV16debugDescriptionSSvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD4KeysV16debugDescriptionSSvp",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "TypeDecl",
+              "name": "Iterator",
+              "printedName": "Iterator",
+              "children": [
+                {
+                  "kind": "Var",
+                  "name": "_base",
+                  "printedName": "_base",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Iterator",
+                      "printedName": "Dictionary<τ_0_0, τ_0_1>.Iterator",
+                      "usr": "s:SD8IteratorV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Iterator",
+                          "printedName": "Dictionary<τ_0_0, τ_0_1>.Iterator",
+                          "usr": "s:SD8IteratorV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SD4KeysV8IteratorV5_baseSDACVyxq__Gvg",
+                      "moduleName": "Swift",
+                      "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SD4KeysV8IteratorV5_baseSDACVyxq__Gvp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 0,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Constructor",
+                  "name": "init",
+                  "printedName": "init(_:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Iterator",
+                      "printedName": "Dictionary<τ_0_0, τ_0_1>.Keys.Iterator",
+                      "usr": "s:SD4KeysV8IteratorV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Iterator",
+                      "printedName": "Dictionary<τ_0_0, τ_0_1>.Iterator",
+                      "usr": "s:SD8IteratorV"
+                    }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:SD4KeysV8IteratorVyADyxq___GSDACVyxq__Gcfc",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "next",
+                  "printedName": "next()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<τ_0_0>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SD4KeysV8IteratorV4nextxSgyF",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+                  "declAttributes": [
+                    "Inlinable"
+                  ],
+                  "mutating": true
+                }
+              ],
+              "declKind": "Struct",
+              "usr": "s:SD4KeysV8IteratorV",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "IteratorProtocol"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "makeIterator",
+              "printedName": "makeIterator()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Iterator",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Keys.Iterator",
+                  "usr": "s:SD4KeysV8IteratorV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD4KeysV12makeIteratorAB0C0Vyxq___GyF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            }
+          ],
           "declKind": "Struct",
           "usr": "s:SD4KeysV",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
           "conformingProtocols": [
             "Collection",
             "Equatable",
             "CustomStringConvertible",
             "CustomDebugStringConvertible",
             "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:SD4KeysV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Key"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "startIndex",
-              "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:SD4KeysV10startIndexSD0C0Vyxq__Gvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD4KeysV10startIndexSD0C0Vyxq__Gvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "Dictionary<Key, Value>.Index",
-                      "usr": "s:SD5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "endIndex",
-              "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:SD4KeysV8endIndexSD0C0Vyxq__Gvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD4KeysV8endIndexSD0C0Vyxq__Gvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "Dictionary<Key, Value>.Index",
-                      "usr": "s:SD5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SD4KeysV5index5afterSD5IndexVyxq__GAG_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "count",
-              "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:SD4KeysV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD4KeysV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "isEmpty",
-              "printedName": "isEmpty",
-              "declKind": "Var",
-              "usr": "s:SD4KeysV7isEmptySbvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD4KeysV7isEmptySbvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Bool",
-                      "printedName": "Bool",
-                      "usr": "s:Sb"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "description",
-              "printedName": "description",
-              "declKind": "Var",
-              "usr": "s:SD4KeysV11descriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD4KeysV11descriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "String",
-                      "printedName": "String",
-                      "usr": "s:SS"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "debugDescription",
-              "printedName": "debugDescription",
-              "declKind": "Var",
-              "usr": "s:SD4KeysV16debugDescriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD4KeysV16debugDescriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "String",
-                      "printedName": "String",
-                      "usr": "s:SS"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:SD4KeysV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:SD4KeysV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<Dictionary<Key, Value>.Keys>",
-                  "usr": "s:s16IndexingIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Keys",
-                      "printedName": "Dictionary<Key, Value>.Keys",
-                      "usr": "s:SD4KeysV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:SD4KeysV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Slice",
-                  "printedName": "Slice<Dictionary<Key, Value>.Keys>",
-                  "usr": "s:s5SliceV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Keys",
-                      "printedName": "Dictionary<Key, Value>.Keys",
-                      "usr": "s:SD4KeysV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:SD4KeysV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DefaultIndices",
-                  "printedName": "DefaultIndices<Dictionary<Key, Value>.Keys>",
-                  "usr": "s:SI",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Keys",
-                      "printedName": "Dictionary<Key, Value>.Keys",
-                      "usr": "s:SD4KeysV"
-                    }
-                  ]
-                }
-              ]
-            }
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Values",
           "printedName": "Values",
-          "declKind": "Struct",
-          "usr": "s:SD6ValuesV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "conformingProtocols": [
-            "MutableCollection",
-            "CustomStringConvertible",
-            "CustomDebugStringConvertible",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:SD6ValuesV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
+              "kind": "Var",
+              "name": "_variant",
+              "printedName": "_variant",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
+                  "name": "_Variant",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>._Variant",
+                  "usr": "s:SD8_VariantO"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_Variant",
+                      "printedName": "Dictionary<τ_0_0, τ_0_1>._Variant",
+                      "usr": "s:SD8_VariantO"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD6ValuesV8_variantSD8_VariantOyxq__Gvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:SD6ValuesV8_variantSD8_VariantOyxq__Gvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:SD6ValuesV10startIndexSD0C0Vyxq__Gvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
                   "usr": "s:SD5IndexV"
                 },
                 {
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD6ValuesV10startIndexSD0C0Vyxq__Gvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Index",
-                      "printedName": "Dictionary<Key, Value>.Index",
+                      "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
                       "usr": "s:SD5IndexV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD6ValuesV10startIndexSD0C0Vyxq__Gvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD6ValuesV10startIndexSD0C0Vyxq__Gvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:SD6ValuesV8endIndexSD0C0Vyxq__Gvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
                   "usr": "s:SD5IndexV"
                 },
                 {
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD6ValuesV8endIndexSD0C0Vyxq__Gvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Index",
-                      "printedName": "Dictionary<Key, Value>.Index",
+                      "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
                       "usr": "s:SD5IndexV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD6ValuesV8endIndexSD0C0Vyxq__Gvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD6ValuesV8endIndexSD0C0Vyxq__Gvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SD6ValuesV5index5afterSD5IndexVyxq__GAG_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
                   "usr": "s:SD5IndexV"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
                   "usr": "s:SD5IndexV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD6ValuesV5index5afterSD5IndexVyxq__GAG_tF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
+              "kind": "Function",
+              "name": "formIndex",
+              "printedName": "formIndex(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD6ValuesV9formIndex5afterySD0C0Vyxq__Gz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SD6ValuesVyq_SD5IndexVyxq__Gcip",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "hasSetter": true
+            },
+            {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:SD6ValuesV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -28741,11 +28382,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD6ValuesV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -28753,21 +28389,24 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD6ValuesV5countSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD6ValuesV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "isEmpty",
               "printedName": "isEmpty",
-              "declKind": "Var",
-              "usr": "s:SD6ValuesV7isEmptySbvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -28779,11 +28418,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD6ValuesV7isEmptySbvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -28791,21 +28425,24 @@
                       "printedName": "Bool",
                       "usr": "s:Sb"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD6ValuesV7isEmptySbvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD6ValuesV7isEmptySbvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "description",
               "printedName": "description",
-              "declKind": "Var",
-              "usr": "s:SD6ValuesV11descriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -28817,11 +28454,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD6ValuesV11descriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -28829,18 +28461,21 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD6ValuesV11descriptionSSvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:SD6ValuesV11descriptionSSvp",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "debugDescription",
               "printedName": "debugDescription",
-              "declKind": "Var",
-              "usr": "s:SD6ValuesV16debugDescriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -28852,11 +28487,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD6ValuesV16debugDescriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -28864,120 +28494,262 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD6ValuesV16debugDescriptionSSvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:SD6ValuesV16debugDescriptionSSvp",
+              "moduleName": "Swift"
             },
             {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:SD6ValuesV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
+              "kind": "Function",
+              "name": "swapAt",
+              "printedName": "swapAt(_:_:)",
               "children": [
                 {
                   "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+                  "usr": "s:SD5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
                   "usr": "s:SD5IndexV"
                 }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:SD6ValuesV11SubSequencea",
-              "location": "",
+              ],
+              "declKind": "Func",
+              "usr": "s:SD6ValuesV6swapAtyySD5IndexVyxq__G_AFtF",
               "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Slice",
-                  "printedName": "Slice<Dictionary<Key, Value>.Values>",
-                  "usr": "s:s5SliceV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Values",
-                      "printedName": "Dictionary<Key, Value>.Values",
-                      "usr": "s:SD6ValuesV"
-                    }
-                  ]
-                }
-              ]
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
-              "kind": "TypeAlias",
+              "kind": "TypeDecl",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:SD6ValuesV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
               "children": [
                 {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<Dictionary<Key, Value>.Values>",
-                  "usr": "s:s16IndexingIteratorV",
+                  "kind": "Var",
+                  "name": "_base",
+                  "printedName": "_base",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Values",
-                      "printedName": "Dictionary<Key, Value>.Values",
-                      "usr": "s:SD6ValuesV"
+                      "name": "Iterator",
+                      "printedName": "Dictionary<τ_0_0, τ_0_1>.Iterator",
+                      "usr": "s:SD8IteratorV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Iterator",
+                          "printedName": "Dictionary<τ_0_0, τ_0_1>.Iterator",
+                          "usr": "s:SD8IteratorV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SD6ValuesV8IteratorV5_baseSDACVyxq__Gvg",
+                      "moduleName": "Swift",
+                      "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
                     }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SD6ValuesV8IteratorV5_baseSDACVyxq__Gvp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 0,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Constructor",
+                  "name": "init",
+                  "printedName": "init(_:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Iterator",
+                      "printedName": "Dictionary<τ_0_0, τ_0_1>.Values.Iterator",
+                      "usr": "s:SD6ValuesV8IteratorV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Iterator",
+                      "printedName": "Dictionary<τ_0_0, τ_0_1>.Iterator",
+                      "usr": "s:SD8IteratorV"
+                    }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:SD6ValuesV8IteratorVyADyxq___GSDACVyxq__Gcfc",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Inlinable"
                   ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "next",
+                  "printedName": "next()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<τ_0_1>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_1"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SD6ValuesV8IteratorV4nextq_SgyF",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+                  "declAttributes": [
+                    "Inlinable"
+                  ],
+                  "mutating": true
                 }
+              ],
+              "declKind": "Struct",
+              "usr": "s:SD6ValuesV8IteratorV",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "IteratorProtocol"
               ]
             },
             {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:SD6ValuesV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
+              "kind": "Function",
+              "name": "makeIterator",
+              "printedName": "makeIterator()",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "DefaultIndices",
-                  "printedName": "DefaultIndices<Dictionary<Key, Value>.Values>",
-                  "usr": "s:SI",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Values",
-                      "printedName": "Dictionary<Key, Value>.Values",
-                      "usr": "s:SD6ValuesV"
-                    }
-                  ]
+                  "name": "Iterator",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Values.Iterator",
+                  "usr": "s:SD6ValuesV8IteratorV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD6ValuesV12makeIteratorAB0C0Vyxq___GyF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SD6ValuesV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "MutableCollection",
+            "CustomStringConvertible",
+            "CustomDebugStringConvertible",
+            "Collection",
+            "Sequence"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:SD"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "Dictionary<τ_0_0, τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:SD"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SDsSQR_rlE2eeoiySbSDyxq_G_ABtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable, τ_0_1 : Equatable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SDsSHR_rlE4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable, Value : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -28990,16 +28762,19 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SDsSHR_rlE4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable, τ_0_1 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SDsSHR_rlE9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -29011,11 +28786,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SDsSHR_rlE9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable, Value : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -29023,21 +28793,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SDsSHR_rlE9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable, τ_0_1 : Hashable>",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SDsSHR_rlE9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:SD11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -29049,11 +28821,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -29061,18 +28828,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SD11descriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:SD16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -29084,11 +28854,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -29096,75 +28861,136 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SD16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeDecl",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "Struct",
-          "usr": "s:SD5IndexV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "conformingProtocols": [
-            "Comparable",
-            "Hashable",
-            "Equatable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Var",
-              "name": "hashValue",
-              "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:SD5IndexV9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
+              "name": "_variant",
+              "printedName": "_variant",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
+                  "name": "_Variant",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index._Variant",
+                  "usr": "s:SD5IndexV8_VariantO"
                 },
                 {
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD5IndexV9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
+                      "name": "_Variant",
+                      "printedName": "Dictionary<τ_0_0, τ_0_1>.Index._Variant",
+                      "usr": "s:SD5IndexV8_VariantO"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD5IndexV8_variantAB8_VariantOyxq___Gvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD5IndexV8_variantAB8_VariantOyxq___Gvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+                  "usr": "s:SD5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD5IndexV2eeoiySbAByxq__G_ADtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+                  "usr": "s:SD5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD5IndexV1loiySbAByxq__G_ADtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:SD5IndexV4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -29177,69 +29003,119 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:SD12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
+              ],
+              "declKind": "Func",
+              "usr": "s:SD5IndexV4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
             },
             {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
+              "kind": "Var",
+              "name": "hashValue",
+              "printedName": "hashValue",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD5IndexV9hashValueSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:SD5IndexV9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SD5IndexV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "Equatable",
+            "Comparable",
+            "Hashable"
           ]
         },
         {
-          "kind": "Function",
-          "name": "popFirst",
-          "printedName": "popFirst()",
-          "declKind": "Func",
-          "usr": "s:SD8popFirstx3key_q_5valuetSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "kind": "TypeDecl",
+          "name": "Iterator",
+          "printedName": "Iterator",
           "children": [
             {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Dictionary<Key, Value>.Element?",
-              "usr": "s:Sq",
+              "kind": "Var",
+              "name": "_variant",
+              "printedName": "_variant",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Dictionary<Key, Value>.Element",
+                  "kind": "TypeNominal",
+                  "name": "_Variant",
+                  "printedName": "Dictionary<τ_0_0, τ_0_1>.Iterator._Variant",
+                  "usr": "s:SD8IteratorV8_VariantO"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_Variant",
+                      "printedName": "Dictionary<τ_0_0, τ_0_1>.Iterator._Variant",
+                      "usr": "s:SD8IteratorV8_VariantO"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD8IteratorV8_variantAB8_VariantOyxq___Gvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD8IteratorV8_variantAB8_VariantOyxq___Gvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Function",
+              "name": "next",
+              "printedName": "next()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<(key: τ_0_0, value: τ_0_1)>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -29258,23 +29134,143 @@
                         }
                       ]
                     }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD8IteratorV4nextx3key_q_5valuetSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
+              ],
+              "mutating": true
+            },
+            {
+              "kind": "Var",
+              "name": "customMirror",
+              "printedName": "customMirror",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Mirror",
+                      "printedName": "Mirror",
+                      "usr": "s:s6MirrorV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD8IteratorV12customMirrors0C0Vvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD8IteratorV12customMirrors0C0Vvp",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SD8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "CustomReflectable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "customMirror",
+          "printedName": "customMirror",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Mirror",
+              "printedName": "Mirror",
+              "usr": "s:s6MirrorV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD12customMirrors0B0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD12customMirrors0B0Vvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "popFirst",
+          "printedName": "popFirst()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<(key: τ_0_0, value: τ_0_1)>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(key: τ_0_0, value: τ_0_1)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SD8popFirstx3key_q_5valuetSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Var",
           "name": "capacity",
           "printedName": "capacity",
-          "declKind": "Var",
-          "usr": "s:SD8capacitySivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -29286,11 +29282,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD8capacitySivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -29298,23 +29289,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD8capacitySivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD8capacitySivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "reserveCapacity",
           "printedName": "reserveCapacity(_:)",
-          "declKind": "Func",
-          "usr": "s:SD15reserveCapacityyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -29327,238 +29319,91 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "keys",
-          "printedName": "keys",
-          "declKind": "Var",
-          "usr": "s:SD4keyss17LazyMapCollectionVySDyxq_GxGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyMapCollection",
-              "printedName": "LazyMapCollection<[Key : Value], Key>",
-              "usr": "s:s17LazyMapCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Dictionary",
-                  "printedName": "[Key : Value]",
-                  "usr": "s:SD",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Key"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD4keyss17LazyMapCollectionVySDyxq_GxGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "LazyMapCollection",
-                  "printedName": "LazyMapCollection<[Key : Value], Key>",
-                  "usr": "s:s17LazyMapCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Dictionary",
-                      "printedName": "[Key : Value]",
-                      "usr": "s:SD",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Key"
-                        },
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Value"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "values",
-          "printedName": "values",
-          "declKind": "Var",
-          "usr": "s:SD6valuess17LazyMapCollectionVySDyxq_Gq_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyMapCollection",
-              "printedName": "LazyMapCollection<[Key : Value], Value>",
-              "usr": "s:s17LazyMapCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Dictionary",
-                  "printedName": "[Key : Value]",
-                  "usr": "s:SD",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD6valuess17LazyMapCollectionVySDyxq_Gq_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "LazyMapCollection",
-                  "printedName": "LazyMapCollection<[Key : Value], Value>",
-                  "usr": "s:s17LazyMapCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Dictionary",
-                      "printedName": "[Key : Value]",
-                      "usr": "s:SD",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Key"
-                        },
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Value"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "filter",
-          "printedName": "filter(_:obsoletedInSwift4:)",
           "declKind": "Func",
-          "usr": "s:SD6filter_17obsoletedInSwift4Sayx3key_q_5valuetGSbxAC_q_ADt_tKXE_yttKF",
-          "location": "",
+          "usr": "s:SD15reserveCapacityyySiF",
           "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Available"
-          ],
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+          "mutating": true
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:SD",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Encodable",
+        "Decodable",
+        "Sequence",
+        "Collection",
+        "ExpressibleByDictionaryLiteral",
+        "Equatable",
+        "Hashable",
+        "_HasCustomAnyHashableRepresentation",
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible",
+        "CustomReflectable"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "LazyDropWhileSequence",
+      "printedName": "LazyDropWhileSequence",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_base",
+          "printedName": "_base",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "[Dictionary<Key, Value>.Element]",
-              "usr": "s:Sa",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Dictionary<Key, Value>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Tuple",
-                      "printedName": "(key: τ_0_0, value: τ_0_1)",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_0"
-                        },
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s21LazyDropWhileSequenceV5_basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
-            },
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s21LazyDropWhileSequenceV5_basexvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_predicate",
+          "printedName": "_predicate",
+          "children": [
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Dictionary<Key, Value>.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -29568,549 +29413,540 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Dictionary<Key, Value>.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "Dictionary<Key, Value>.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Tuple",
-                          "printedName": "(key: τ_0_0, value: τ_0_1)",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GenericTypeParam",
-                              "printedName": "τ_0_0"
-                            },
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GenericTypeParam",
-                              "printedName": "τ_0_1"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
               ]
             },
             {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()",
-              "hasDefaultArg": true
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "DictionaryIndex",
-      "printedName": "DictionaryIndex",
-      "declKind": "TypeAlias",
-      "usr": "s:s15DictionaryIndexa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Key, Value where Key : Hashable>",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Index",
-          "printedName": "Dictionary<Key, Value>.Index",
-          "usr": "s:SD5IndexV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "DictionaryIterator",
-      "printedName": "DictionaryIterator",
-      "declKind": "Struct",
-      "usr": "s:s18DictionaryIteratorV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Key, Value where Key : Hashable>",
-      "conformingProtocols": [
-        "IteratorProtocol",
-        "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Function",
-          "name": "next",
-          "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s18DictionaryIteratorV4nextx3key_q_5valuetSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "(key: Key, value: Value)?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(key: Key, value: Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s18DictionaryIteratorV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(key: Key, value: Value)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Key"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s18DictionaryIteratorV12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s18DictionaryIteratorV12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
               "children": [
                 {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
+                  "kind": "TypeFunc",
+                  "name": "Function",
+                  "printedName": "(τ_0_0.Element) -> Bool",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    }
+                  ]
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s21LazyDropWhileSequenceV10_predicateySb7ElementQzcvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "LazyDropWhileSequence",
-      "printedName": "LazyDropWhileSequence",
-      "declKind": "Struct",
-      "usr": "s:s21LazyDropWhileSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Sequence>",
-      "conformingProtocols": [
-        "Sequence",
-        "LazySequenceProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s21LazyDropWhileSequenceV7Elementa",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s21LazyDropWhileSequenceV10_predicateySb7ElementQzcvp",
           "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element"
-            }
-          ]
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s21LazyDropWhileSequenceV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "conformingProtocols": [
-            "IteratorProtocol"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s21LazyDropWhileSequenceV8IteratorV7Elementa",
-              "location": "",
+              "kind": "Var",
+              "name": "_predicateHasFailed",
+              "printedName": "_predicateHasFailed",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s21LazyDropWhileSequenceV8IteratorV19_predicateHasFailedSbvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s21LazyDropWhileSequenceV8IteratorV19_predicateHasFailedSbvp",
               "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
+              "isInternal": true,
+              "declAttributes": [
+                "HasInitialValue",
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_base",
+              "printedName": "_base",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Base.Element"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "next",
-              "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s21LazyDropWhileSequenceV8IteratorV4next7ElementQzSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
+                  "printedName": "τ_0_0.Iterator"
+                },
                 {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "LazyDropWhileSequence<Base>.Iterator.Element?",
-                  "usr": "s:Sq",
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "LazyDropWhileSequence<Base>.Iterator.Element",
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Iterator"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s21LazyDropWhileSequenceV8IteratorV5_baseACQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s21LazyDropWhileSequenceV8IteratorV5_baseACQzvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 1,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_predicate",
+              "printedName": "_predicate",
+              "children": [
+                {
+                  "kind": "TypeFunc",
+                  "name": "Function",
+                  "printedName": "(τ_0_0.Element) -> Bool",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    }
+                  ]
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeFunc",
+                      "name": "Function",
+                      "printedName": "(τ_0_0.Element) -> Bool",
                       "children": [
                         {
                           "kind": "TypeNominal",
+                          "name": "Bool",
+                          "printedName": "Bool",
+                          "usr": "s:Sb"
+                        },
+                        {
+                          "kind": "TypeNominal",
                           "name": "DependentMember",
                           "printedName": "τ_0_0.Element"
                         }
                       ]
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s21LazyDropWhileSequenceV8IteratorV10_predicateySb7ElementQzcvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s21LazyDropWhileSequenceV03SubD0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "children": [
+              ],
+              "declKind": "Var",
+              "usr": "s:s21LazyDropWhileSequenceV8IteratorV10_predicateySb7ElementQzcvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 2,
+              "isLet": true,
+              "hasStorage": true
+            },
             {
-              "kind": "TypeNominal",
-              "name": "AnySequence",
-              "printedName": "AnySequence<Base.Element>",
-              "usr": "s:s11AnySequenceV",
+              "kind": "Function",
+              "name": "next",
+              "printedName": "next()",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Element"
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_0.Element>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    }
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s21LazyDropWhileSequenceV8IteratorV4next7ElementQzSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s21LazyDropWhileSequenceV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s21LazyDropWhileSequenceV12makeIteratorAB0F0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Iterator",
-              "printedName": "LazyDropWhileSequence<Base>.Iterator",
+              "printedName": "LazyDropWhileSequence<τ_0_0>.Iterator",
               "usr": "s:s21LazyDropWhileSequenceV8IteratorV"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Elements",
-          "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s21LazyDropWhileSequenceV8Elementsa",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s21LazyDropWhileSequenceV12makeIteratorAB0F0Vyx_GyF",
           "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyDropWhileSequence",
-              "printedName": "LazyDropWhileSequence<Base>",
-              "usr": "s:s21LazyDropWhileSequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s21LazyDropWhileSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "LazySequenceProtocol"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "LazyDropWhileCollection",
       "printedName": "LazyDropWhileCollection",
-      "declKind": "Struct",
-      "usr": "s:s23LazyDropWhileCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Collection>",
-      "conformingProtocols": [
-        "Sequence",
-        "Collection",
-        "LazyCollectionProtocol",
-        "LazySequenceProtocol",
-        "BidirectionalCollection"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s23LazyDropWhileCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
+          "kind": "Var",
+          "name": "_base",
+          "printedName": "_base",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element"
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s23LazyDropWhileCollectionV5_basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s23LazyDropWhileCollectionV5_basexvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
         },
         {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s23LazyDropWhileCollectionV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
+          "kind": "Var",
+          "name": "_predicate",
+          "printedName": "_predicate",
           "children": [
             {
-              "kind": "TypeNominal",
-              "name": "Iterator",
-              "printedName": "LazyDropWhileSequence<Base>.Iterator",
-              "usr": "s:s21LazyDropWhileSequenceV8IteratorV"
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Element) -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ]
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeFunc",
+                  "name": "Function",
+                  "printedName": "(τ_0_0.Element) -> Bool",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    }
+                  ]
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s23LazyDropWhileCollectionV10_predicateySb7ElementQzcvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s23LazyDropWhileCollectionV10_predicateySb7ElementQzcvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s23LazyDropWhileCollectionV12makeIterators0abC8SequenceV0F0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Iterator",
-              "printedName": "LazyDropWhileCollection<Base>.Iterator",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "LazyDropWhileSequence<τ_0_0>.Iterator",
-                  "usr": "s:s21LazyDropWhileSequenceV8IteratorV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s23LazyDropWhileCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<LazyDropWhileCollection<Base>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "LazyDropWhileCollection",
-                  "printedName": "LazyDropWhileCollection<Base>",
-                  "usr": "s:s23LazyDropWhileCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Base"
-                    }
-                  ]
-                }
-              ]
+              "name": "Iterator",
+              "printedName": "LazyDropWhileSequence<τ_0_0>.Iterator",
+              "usr": "s:s21LazyDropWhileSequenceV8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s23LazyDropWhileCollectionV12makeIterators0abC8SequenceV0F0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "Struct",
-          "usr": "s:s23LazyDropWhileCollectionV5IndexV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "conformingProtocols": [
-            "Equatable",
-            "Comparable",
-            "Hashable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "base",
               "printedName": "base",
-              "declKind": "Var",
-              "usr": "s:s23LazyDropWhileCollectionV5IndexV4baseACQzvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Base.Index"
+                  "printedName": "τ_0_0.Index"
                 },
                 {
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s23LazyDropWhileCollectionV5IndexV4baseACQzvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Base where Base : Collection>",
-                  "declAttributes": [
-                    "Transparent"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Base.Index"
+                      "printedName": "τ_0_0.Index"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s23LazyDropWhileCollectionV5IndexV4baseACQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+                  "implicit": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s23LazyDropWhileCollectionV5IndexV4baseACQzvp",
+              "moduleName": "Swift",
+              "fixedbinaryorder": 0,
+              "isLet": true,
+              "hasStorage": true
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "LazyDropWhileCollection<τ_0_0>.Index",
+                  "usr": "s:s23LazyDropWhileCollectionV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "LazyDropWhileCollection<τ_0_0>.Index",
+                  "usr": "s:s23LazyDropWhileCollectionV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s23LazyDropWhileCollectionV5IndexV2eeoiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "LazyDropWhileCollection<τ_0_0>.Index",
+                  "usr": "s:s23LazyDropWhileCollectionV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "LazyDropWhileCollection<τ_0_0>.Index",
+                  "usr": "s:s23LazyDropWhileCollectionV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s23LazyDropWhileCollectionV5IndexV1loiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s23LazyDropWhileCollectionV5IndexVsSHACRpzrlE9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -30122,11 +29958,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s23LazyDropWhileCollectionV5IndexVsSHACRpzrlE9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Base where Base : Collection, Base.Index : Hashable>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -30134,22 +29965,24 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s23LazyDropWhileCollectionV5IndexVsSHACRpzrlE9hashValueSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Index : Hashable>"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s23LazyDropWhileCollectionV5IndexVsSHACRpzrlE9hashValueSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s23LazyDropWhileCollectionV5IndexVsSHACRpzrlE4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection, Base.Index : Hashable>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -30162,236 +29995,218 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s23LazyDropWhileCollectionV5IndexVsSHACRpzrlE4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Index : Hashable>",
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s23LazyDropWhileCollectionV5IndexV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "Equatable",
+            "Comparable",
+            "Hashable"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s23LazyDropWhileCollectionV10startIndexAB0F0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "LazyDropWhileCollection<Base>.Index",
+              "printedName": "LazyDropWhileCollection<τ_0_0>.Index",
               "usr": "s:s23LazyDropWhileCollectionV5IndexV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s23LazyDropWhileCollectionV10startIndexAB0F0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "LazyDropWhileCollection<Base>.Index",
+                  "printedName": "LazyDropWhileCollection<τ_0_0>.Index",
                   "usr": "s:s23LazyDropWhileCollectionV5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s23LazyDropWhileCollectionV10startIndexAB0F0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s23LazyDropWhileCollectionV10startIndexAB0F0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s23LazyDropWhileCollectionV8endIndexAB0F0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "LazyDropWhileCollection<Base>.Index",
+              "printedName": "LazyDropWhileCollection<τ_0_0>.Index",
               "usr": "s:s23LazyDropWhileCollectionV5IndexV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s23LazyDropWhileCollectionV8endIndexAB0F0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "LazyDropWhileCollection<Base>.Index",
+                  "printedName": "LazyDropWhileCollection<τ_0_0>.Index",
                   "usr": "s:s23LazyDropWhileCollectionV5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s23LazyDropWhileCollectionV8endIndexAB0F0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s23LazyDropWhileCollectionV8endIndexAB0F0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s23LazyDropWhileCollectionV5index5afterAB5IndexVyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "LazyDropWhileCollection<Base>.Index",
+              "printedName": "LazyDropWhileCollection<τ_0_0>.Index",
               "usr": "s:s23LazyDropWhileCollectionV5IndexV"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "LazyDropWhileCollection<Base>.Index",
+              "printedName": "LazyDropWhileCollection<τ_0_0>.Index",
               "usr": "s:s23LazyDropWhileCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s23LazyDropWhileCollectionV5index5afterAB5IndexVyx_GAG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s23LazyDropWhileCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "DefaultIndices",
-              "printedName": "DefaultIndices<LazyDropWhileCollection<Base>>",
-              "usr": "s:SI",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "LazyDropWhileCollection",
-                  "printedName": "LazyDropWhileCollection<Base>",
-                  "usr": "s:s23LazyDropWhileCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Base"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Elements",
-          "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s23LazyDropWhileCollectionV8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            },
             {
               "kind": "TypeNominal",
-              "name": "LazyDropWhileCollection",
-              "printedName": "LazyDropWhileCollection<Base>",
-              "usr": "s:s23LazyDropWhileCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                }
-              ]
+              "name": "Index",
+              "printedName": "LazyDropWhileCollection<τ_0_0>.Index",
+              "usr": "s:s23LazyDropWhileCollectionV5IndexV"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s23LazyDropWhileCollectionVy7ElementQzAB5IndexVyx_Gcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s23LazyDropWhileCollectionVsSKRzrlE5index6beforeAB5IndexVyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "LazyDropWhileCollection<Base>.Index",
+              "printedName": "LazyDropWhileCollection<τ_0_0>.Index",
               "usr": "s:s23LazyDropWhileCollectionV5IndexV"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "LazyDropWhileCollection<Base>.Index",
+              "printedName": "LazyDropWhileCollection<τ_0_0>.Index",
               "usr": "s:s23LazyDropWhileCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s23LazyDropWhileCollectionVsSKRzrlE5index6beforeAB5IndexVyx_GAG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s23LazyDropWhileCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "Collection",
+        "LazyCollectionProtocol",
+        "LazySequenceProtocol",
+        "BidirectionalCollection"
       ]
     },
     {
       "kind": "Function",
       "name": "dump",
       "printedName": "dump(_:to:name:indent:maxDepth:maxItems:)",
-      "declKind": "Func",
-      "usr": "s:s4dump_2to4name6indent8maxDepth0E5Itemsxx_q_zSSSgS3its16TextOutputStreamR_r0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, TargetStream where TargetStream : TextOutputStream>",
-      "declAttributes": [
-        "Semantics",
-        "DiscardableResult",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "TargetStream"
+          "printedName": "τ_0_1"
         },
         {
           "kind": "TypeNominal",
           "name": "Optional",
-          "printedName": "String?",
-          "hasDefaultArg": true,
-          "usr": "s:Sq",
+          "printedName": "Optional<String>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -30399,7 +30214,9 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "hasDefaultArg": true,
+          "usr": "s:Sq"
         },
         {
           "kind": "TypeNominal",
@@ -30422,39 +30239,35 @@
           "hasDefaultArg": true,
           "usr": "s:Si"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s4dump_2to4name6indent8maxDepth0E5Itemsxx_q_zSSSgS3its16TextOutputStreamR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1 where τ_0_1 : TextOutputStream>",
+      "declAttributes": [
+        "Semantics",
+        "DiscardableResult"
       ]
     },
     {
       "kind": "Function",
       "name": "dump",
       "printedName": "dump(_:name:indent:maxDepth:maxItems:)",
-      "declKind": "Func",
-      "usr": "s:s4dump_4name6indent8maxDepth0D5Itemsxx_SSSgS3itlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "declAttributes": [
-        "Semantics",
-        "DiscardableResult",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "Optional",
-          "printedName": "String?",
-          "hasDefaultArg": true,
-          "usr": "s:Sq",
+          "printedName": "Optional<String>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -30462,7 +30275,9 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "hasDefaultArg": true,
+          "usr": "s:Sq"
         },
         {
           "kind": "TypeNominal",
@@ -30485,17 +30300,527 @@
           "hasDefaultArg": true,
           "usr": "s:Si"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s4dump_4name6indent8maxDepth0D5Itemsxx_SSSgS3itlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "Semantics",
+        "DiscardableResult"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "EmptyCollection",
       "printedName": "EmptyCollection",
+      "children": [
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "EmptyCollection",
+              "printedName": "EmptyCollection<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s15EmptyCollectionV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s15EmptyCollectionVAByxGycfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "Iterator",
+          "printedName": "Iterator",
+          "children": [
+            {
+              "kind": "Constructor",
+              "name": "init",
+              "printedName": "init()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Iterator",
+                  "printedName": "EmptyCollection<τ_0_0>.Iterator",
+                  "usr": "s:s15EmptyCollectionV8IteratorV"
+                }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s15EmptyCollectionV8IteratorVADyx_Gycfc",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "next",
+              "printedName": "next()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s15EmptyCollectionV8IteratorV4nextxSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s15EmptyCollectionV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "Sequence"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "makeIterator",
+          "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Iterator",
+              "printedName": "EmptyCollection<τ_0_0>.Iterator",
+              "usr": "s:s15EmptyCollectionV8IteratorV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15EmptyCollectionV12makeIteratorAB0D0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15EmptyCollectionV10startIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15EmptyCollectionV10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15EmptyCollectionV8endIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15EmptyCollectionV8endIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15EmptyCollectionV5index5afterS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15EmptyCollectionV5index6beforeS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s15EmptyCollectionVyxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "EmptyCollection",
+              "printedName": "EmptyCollection<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s15EmptyCollectionV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s15EmptyCollectionVyAByxGSnySiGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Var",
+          "name": "count",
+          "printedName": "count",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15EmptyCollectionV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15EmptyCollectionV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15EmptyCollectionV5index_8offsetByS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:limitedBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15EmptyCollectionV5index_8offsetBy07limitedE0SiSgSi_S2itF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(from:to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15EmptyCollectionV8distance4from2toS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "EmptyCollection",
+              "printedName": "EmptyCollection<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s15EmptyCollectionV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "EmptyCollection",
+              "printedName": "EmptyCollection<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s15EmptyCollectionV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15EmptyCollectionV2eeoiySbAByxG_ADtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        }
+      ],
       "declKind": "Struct",
       "usr": "s:s15EmptyCollectionV",
-      "location": "",
       "moduleName": "Swift",
-      "genericSig": "<Element>",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "Sequence",
         "RandomAccessCollection",
@@ -30503,1472 +30828,17 @@
         "BidirectionalCollection",
         "Collection",
         "Equatable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s15EmptyCollectionVAByxGycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "EmptyCollection",
-              "printedName": "EmptyCollection<Element>",
-              "usr": "s:s15EmptyCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeDecl",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s15EmptyCollectionV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "conformingProtocols": [
-            "IteratorProtocol",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "Constructor",
-              "name": "init",
-              "printedName": "init()",
-              "declKind": "Constructor",
-              "usr": "s:s15EmptyCollectionV8IteratorVADyx_Gycfc",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "EmptyCollection<Element>.Iterator",
-                  "usr": "s:s15EmptyCollectionV8IteratorV"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "next",
-              "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s15EmptyCollectionV8IteratorV4nextxSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "Element?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s15EmptyCollectionV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s15EmptyCollectionV8IteratorVACa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "EmptyCollection<Element>.Iterator",
-                  "usr": "s:s15EmptyCollectionV8IteratorV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s15EmptyCollectionV8IteratorV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnySequence",
-                  "printedName": "AnySequence<Element>",
-                  "usr": "s:s11AnySequenceV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "makeIterator",
-          "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s15EmptyCollectionV12makeIteratorAB0D0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Iterator",
-              "printedName": "EmptyCollection<Element>.Iterator",
-              "usr": "s:s15EmptyCollectionV8IteratorV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s15EmptyCollectionV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s15EmptyCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Int>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s15EmptyCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "EmptyCollection",
-              "printedName": "EmptyCollection<Element>",
-              "usr": "s:s15EmptyCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s15EmptyCollectionV10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "EmptyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15EmptyCollectionV10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "EmptyCollection<Element>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s15EmptyCollectionV8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "EmptyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15EmptyCollectionV8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "EmptyCollection<Element>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s15EmptyCollectionV5index5afterS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "EmptyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "EmptyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s15EmptyCollectionV5index6beforeS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "EmptyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "EmptyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "count",
-          "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s15EmptyCollectionV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15EmptyCollectionV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s15EmptyCollectionV5index_8offsetByS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "EmptyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "EmptyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s15EmptyCollectionV5index_8offsetBy07limitedE0SiSgSi_S2itF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "EmptyCollection<Element>.Index?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "EmptyCollection<Element>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "EmptyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "EmptyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s15EmptyCollectionV8distance4from2toS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "EmptyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "EmptyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s15EmptyCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        }
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Equatable",
       "printedName": "Equatable",
-      "declKind": "Protocol",
-      "usr": "s:SQ",
-      "location": "",
-      "moduleName": "Swift"
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "Error",
-      "printedName": "Error",
-      "declKind": "Protocol",
-      "usr": "s:s5ErrorP",
-      "location": "",
-      "moduleName": "Swift"
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "LazyFilterSequence",
-      "printedName": "LazyFilterSequence",
-      "declKind": "Struct",
-      "usr": "s:s18LazyFilterSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Sequence>",
-      "conformingProtocols": [
-        "LazySequenceProtocol",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeDecl",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s18LazyFilterSequenceV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "conformingProtocols": [
-            "IteratorProtocol",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "Var",
-              "name": "base",
-              "printedName": "base",
-              "declKind": "Var",
-              "usr": "s:s18LazyFilterSequenceV8IteratorV4baseACQzvp",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Iterator"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s18LazyFilterSequenceV8IteratorV4baseACQzvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Base where Base : Sequence>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Base.Iterator"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s18LazyFilterSequenceV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Element"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "next",
-              "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s18LazyFilterSequenceV8IteratorV4next7ElementQzSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "LazyFilterSequence<Base>.Iterator.Element?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "LazyFilterSequence<Base>.Iterator.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "DependentMember",
-                          "printedName": "τ_0_0.Element"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s18LazyFilterSequenceV8IteratorVACa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "LazyFilterSequence<Base>.Iterator",
-                  "usr": "s:s18LazyFilterSequenceV8IteratorV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s18LazyFilterSequenceV8IteratorV03SubC0a",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnySequence",
-                  "printedName": "AnySequence<Base.Element>",
-                  "usr": "s:s11AnySequenceV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Base.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s18LazyFilterSequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element"
-            }
-          ]
-        },
-        {
           "kind": "Function",
-          "name": "makeIterator",
-          "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s18LazyFilterSequenceV12makeIteratorAB0E0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Iterator",
-              "printedName": "LazyFilterSequence<Base>.Iterator",
-              "usr": "s:s18LazyFilterSequenceV8IteratorV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Elements",
-          "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s18LazyFilterSequenceV8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyFilterSequence",
-              "printedName": "LazyFilterSequence<Base>",
-              "usr": "s:s18LazyFilterSequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s18LazyFilterSequenceV03SubC0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnySequence",
-              "printedName": "AnySequence<Base.Element>",
-              "usr": "s:s11AnySequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Element"
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "LazyFilterCollection",
-      "printedName": "LazyFilterCollection",
-      "declKind": "Struct",
-      "usr": "s:s20LazyFilterCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Collection>",
-      "conformingProtocols": [
-        "LazySequenceProtocol",
-        "Sequence",
-        "LazyCollectionProtocol",
-        "Collection",
-        "BidirectionalCollection"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s20LazyFilterCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s20LazyFilterCollectionV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Iterator",
-              "printedName": "LazyFilterSequence<Base>.Iterator",
-              "usr": "s:s18LazyFilterSequenceV8IteratorV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s20LazyFilterCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyFilterCollection",
-              "printedName": "LazyFilterCollection<Base.SubSequence>",
-              "usr": "s:s20LazyFilterCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.SubSequence"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "underestimatedCount",
-          "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s20LazyFilterCollectionV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20LazyFilterCollectionV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "makeIterator",
-          "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionV12makeIterators0aB8SequenceV0E0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Iterator",
-              "printedName": "LazyFilterCollection<Base>.Iterator",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "LazyFilterSequence<τ_0_0>.Iterator",
-                  "usr": "s:s18LazyFilterSequenceV8IteratorV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Elements",
-          "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s20LazyFilterCollectionV8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyFilterCollection",
-              "printedName": "LazyFilterCollection<Base>",
-              "usr": "s:s20LazyFilterCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s20LazyFilterCollectionV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Index"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s20LazyFilterCollectionV10startIndex0E0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Index"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20LazyFilterCollectionV10startIndex0E0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s20LazyFilterCollectionV8endIndex0E0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Index"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20LazyFilterCollectionV8endIndex0E0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionV5index5after5IndexQzAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyFilterCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyFilterCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionV9formIndex5aftery0E0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyFilterCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionV8distance4from2toSi5IndexQz_AGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyFilterCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyFilterCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionV5index_8offsetBy5IndexQzAF_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyFilterCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyFilterCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionV9formIndex_8offsetByy0E0Qzz_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyFilterCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionV5index_8offsetBy07limitedF05IndexQzSgAG_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "LazyFilterCollection<Base>.Index?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "LazyFilterCollection<Base>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "τ_0_0.Index"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyFilterCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyFilterCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionV9formIndex_8offsetBy07limitedG0Sb0E0Qzz_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "name": "==",
+          "printedName": "==(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -31977,16 +30847,894 @@
               "usr": "s:Sb"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyFilterCollection<Base>.Index",
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SQ2eeoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Equatable>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "!=",
+          "printedName": "!=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SQsE2neoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Equatable>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SQ",
+      "moduleName": "Swift"
+    },
+    {
+      "kind": "Function",
+      "name": "===",
+      "printedName": "===(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "Optional<AnyObject>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ProtocolComposition",
+              "printedName": "AnyObject"
+            }
+          ],
+          "usr": "s:Sq"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "Optional<AnyObject>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ProtocolComposition",
+              "printedName": "AnyObject"
+            }
+          ],
+          "usr": "s:Sq"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s3eeeoiySbyXlSg_ABtF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!==",
+      "printedName": "!==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "Optional<AnyObject>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ProtocolComposition",
+              "printedName": "AnyObject"
+            }
+          ],
+          "usr": "s:Sq"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "Optional<AnyObject>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ProtocolComposition",
+              "printedName": "AnyObject"
+            }
+          ],
+          "usr": "s:Sq"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s3neeoiySbyXlSg_ABtF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Error",
+      "printedName": "Error",
+      "declKind": "Protocol",
+      "usr": "s:s5ErrorP",
+      "moduleName": "Swift"
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "LazyFilterSequence",
+      "printedName": "LazyFilterSequence",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_base",
+          "printedName": "_base",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s18LazyFilterSequenceV5_basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s18LazyFilterSequenceV5_basexvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_predicate",
+          "printedName": "_predicate",
+          "children": [
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Element) -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ]
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeFunc",
+                  "name": "Function",
+                  "printedName": "(τ_0_0.Element) -> Bool",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    }
+                  ]
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s18LazyFilterSequenceV10_predicateySb7ElementQzcvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s18LazyFilterSequenceV10_predicateySb7ElementQzcvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "Iterator",
+          "printedName": "Iterator",
+          "children": [
+            {
+              "kind": "Var",
+              "name": "base",
+              "printedName": "base",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Iterator"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Iterator"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s18LazyFilterSequenceV8IteratorV4baseACQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s18LazyFilterSequenceV8IteratorV4baseACQzvp",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Var",
+              "name": "_base",
+              "printedName": "_base",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Iterator"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Iterator"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s18LazyFilterSequenceV8IteratorV5_baseACQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s18LazyFilterSequenceV8IteratorV5_baseACQzvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_predicate",
+              "printedName": "_predicate",
+              "children": [
+                {
+                  "kind": "TypeFunc",
+                  "name": "Function",
+                  "printedName": "(τ_0_0.Element) -> Bool",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    }
+                  ]
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeFunc",
+                      "name": "Function",
+                      "printedName": "(τ_0_0.Element) -> Bool",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Bool",
+                          "printedName": "Bool",
+                          "usr": "s:Sb"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "DependentMember",
+                          "printedName": "τ_0_0.Element"
+                        }
+                      ]
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s18LazyFilterSequenceV8IteratorV10_predicateySb7ElementQzcvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s18LazyFilterSequenceV8IteratorV10_predicateySb7ElementQzcvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 1,
+              "isLet": true,
+              "hasStorage": true
+            },
+            {
+              "kind": "Function",
+              "name": "next",
+              "printedName": "next()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_0.Element>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s18LazyFilterSequenceV8IteratorV4next7ElementQzSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s18LazyFilterSequenceV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "Sequence"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "makeIterator",
+          "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Iterator",
+              "printedName": "LazyFilterSequence<τ_0_0>.Iterator",
+              "usr": "s:s18LazyFilterSequenceV8IteratorV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s18LazyFilterSequenceV12makeIteratorAB0E0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s18LazyFilterSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "LazySequenceProtocol",
+        "Sequence"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "LazyFilterCollection",
+      "printedName": "LazyFilterCollection",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_base",
+          "printedName": "_base",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20LazyFilterCollectionV5_basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20LazyFilterCollectionV5_basexvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_predicate",
+          "printedName": "_predicate",
+          "children": [
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Element) -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ]
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeFunc",
+                  "name": "Function",
+                  "printedName": "(τ_0_0.Element) -> Bool",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    }
+                  ]
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20LazyFilterCollectionV10_predicateySb7ElementQzcvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20LazyFilterCollectionV10_predicateySb7ElementQzcvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "underestimatedCount",
+          "printedName": "underestimatedCount",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20LazyFilterCollectionV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20LazyFilterCollectionV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "makeIterator",
+          "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Iterator",
+              "printedName": "LazyFilterSequence<τ_0_0>.Iterator",
+              "usr": "s:s18LazyFilterSequenceV8IteratorV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionV12makeIterators0aB8SequenceV0E0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20LazyFilterCollectionV10startIndex0E0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20LazyFilterCollectionV10startIndex0E0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20LazyFilterCollectionV8endIndex0E0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20LazyFilterCollectionV8endIndex0E0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionV5index5after5IndexQzAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionV9formIndex5aftery0E0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(from:to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionV8distance4from2toSi5IndexQz_AGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionV5index_8offsetBy5IndexQzAF_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(_:offsetBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionV9formIndex_8offsetByy0E0Qzz_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:limitedBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
@@ -31995,103 +31743,147 @@
               "usr": "s:Si"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyFilterCollection<Base>.Index",
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionV5index_8offsetBy07limitedF05IndexQzSgAG_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(_:offsetBy:limitedBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionV9formIndex_8offsetBy07limitedG0Sb0E0Qzz_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s20LazyFilterCollectionVy7ElementQz5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyFilterCollection",
+              "printedName": "LazyFilterCollection<τ_0_0.SubSequence>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.SubSequence"
+                }
+              ],
+              "usr": "s:s20LazyFilterCollectionV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s20LazyFilterCollectionV7Indicesa",
-          "location": "",
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s20LazyFilterCollectionVyABy11SubSequenceQzGSny5IndexQzGcip",
           "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DefaultIndices",
-              "printedName": "DefaultIndices<LazyFilterCollection<Base>>",
-              "usr": "s:SI",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "LazyFilterCollection",
-                  "printedName": "LazyFilterCollection<Base>",
-                  "usr": "s:s20LazyFilterCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Base"
-                    }
-                  ]
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionVsSKRzrlE5index6before5IndexQzAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyFilterCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyFilterCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionVsSKRzrlE5index6before5IndexQzAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionVsSKRzrlE9formIndex6beforey0E0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32099,298 +31891,517 @@
               "printedName": "()"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyFilterCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionVsSKRzrlE9formIndex6beforey0E0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s20LazyFilterCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "LazySequenceProtocol",
+        "Sequence",
+        "LazyCollectionProtocol",
+        "Collection",
+        "BidirectionalCollection"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "FlattenSequence",
       "printedName": "FlattenSequence",
-      "declKind": "Struct",
-      "usr": "s:s15FlattenSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-      "conformingProtocols": [
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
+          "kind": "Var",
+          "name": "_base",
+          "printedName": "_base",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15FlattenSequenceV5_basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15FlattenSequenceV5_basexvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s15FlattenSequenceV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-          "conformingProtocols": [
-            "IteratorProtocol",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s15FlattenSequenceV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
+              "kind": "Var",
+              "name": "_base",
+              "printedName": "_base",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Base.Element.Element"
+                  "printedName": "τ_0_0.Iterator"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Iterator"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s15FlattenSequenceV8IteratorV5_baseACQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s15FlattenSequenceV8IteratorV5_baseACQzvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_inner",
+              "printedName": "_inner",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_0.Element.Iterator>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element.Iterator"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<τ_0_0.Element.Iterator>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "DependentMember",
+                          "printedName": "τ_0_0.Element.Iterator"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s15FlattenSequenceV8IteratorV6_inner7Element_ACQZSgvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s15FlattenSequenceV8IteratorV6_inner7Element_ACQZSgvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "HasInitialValue",
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 1,
+              "hasStorage": true
             },
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s15FlattenSequenceV8IteratorV4next7Element_AFQZSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "FlattenSequence<Base>.Iterator.Element?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "FlattenSequence<Base>.Iterator.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "DependentMember",
-                          "printedName": "τ_0_0.Element.Element"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s15FlattenSequenceV8IteratorVACa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "FlattenSequence<Base>.Iterator",
-                  "usr": "s:s15FlattenSequenceV8IteratorV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s15FlattenSequenceV8IteratorV03SubB0a",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnySequence",
-                  "printedName": "AnySequence<Base.Element.Element>",
-                  "usr": "s:s11AnySequenceV",
+                  "printedName": "Optional<τ_0_0.Element.Element>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Base.Element.Element"
+                      "printedName": "τ_0_0.Element.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s15FlattenSequenceV8IteratorV4next7Element_AFQZSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s15FlattenSequenceV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "Sequence"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s15FlattenSequenceV12makeIteratorAB0D0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Iterator",
-              "printedName": "FlattenSequence<Base>.Iterator",
+              "printedName": "FlattenSequence<τ_0_0>.Iterator",
               "usr": "s:s15FlattenSequenceV8IteratorV"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s15FlattenSequenceV7Elementa",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s15FlattenSequenceV12makeIteratorAB0D0Vyx_GyF",
           "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element.Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s15FlattenSequenceV03SubB0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnySequence",
-              "printedName": "AnySequence<Base.Element.Element>",
-              "usr": "s:s11AnySequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Element.Element"
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s15FlattenSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "FlattenCollection",
       "printedName": "FlattenCollection",
-      "declKind": "Struct",
-      "usr": "s:s17FlattenCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-      "conformingProtocols": [
-        "Sequence",
-        "Collection",
-        "BidirectionalCollection"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FlattenCollectionVyAByxGxcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "kind": "Var",
+          "name": "_base",
+          "printedName": "_base",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "FlattenCollection",
-              "printedName": "FlattenCollection<Base>",
-              "usr": "s:s17FlattenCollectionV",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Base"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FlattenCollectionV5_basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FlattenCollectionV5_basexvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "FlattenCollection",
+              "printedName": "FlattenCollection<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s17FlattenCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Base"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FlattenCollectionVyAByxGxcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "Struct",
-          "usr": "s:s17FlattenCollectionV5IndexV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "conformingProtocols": [
-            "Equatable",
-            "Comparable",
-            "Hashable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
+              "kind": "Var",
+              "name": "_outer",
+              "printedName": "_outer",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Index"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s17FlattenCollectionV5IndexV6_outerACQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s17FlattenCollectionV5IndexV6_outerACQzvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "isLet": true,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_inner",
+              "printedName": "_inner",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_0.Element.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element.Index"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<τ_0_0.Element.Index>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "DependentMember",
+                          "printedName": "τ_0_0.Element.Index"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s17FlattenCollectionV5IndexV6_inner7Element_ACQZSgvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s17FlattenCollectionV5IndexV6_inner7Element_ACQZSgvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 1,
+              "isLet": true,
+              "hasStorage": true
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "FlattenCollection<τ_0_0>.Index",
+                  "usr": "s:s17FlattenCollectionV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "FlattenCollection<τ_0_0>.Index",
+                  "usr": "s:s17FlattenCollectionV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s17FlattenCollectionV5IndexV2eeoiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "FlattenCollection<τ_0_0>.Index",
+                  "usr": "s:s17FlattenCollectionV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "FlattenCollection<τ_0_0>.Index",
+                  "usr": "s:s17FlattenCollectionV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s17FlattenCollectionV5IndexV1loiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s17FlattenCollectionV5IndexVsSHACRpzSH7Element_ACRPzrlE4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection, Base.Element : Collection, Base.Index : Hashable, Base.Element.Index : Hashable>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -32403,16 +32414,19 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s17FlattenCollectionV5IndexVsSHACRpzSH7Element_ACRPzrlE4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection, τ_0_0.Index : Hashable, τ_0_0.Element.Index : Hashable>",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s17FlattenCollectionV5IndexVsSHACRpzSH7Element_ACRPzrlE9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -32424,11 +32438,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s17FlattenCollectionV5IndexVsSHACRpzSH7Element_ACRPzrlE9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Base where Base : Collection, Base.Element : Collection, Base.Index : Hashable, Base.Element.Index : Hashable>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -32436,99 +32445,57 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s17FlattenCollectionV5IndexVsSHACRpzSH7Element_ACRPzrlE9hashValueSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection, τ_0_0.Index : Hashable, τ_0_0.Element.Index : Hashable>",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s17FlattenCollectionV5IndexVsSHACRpzSH7Element_ACRPzrlE9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s17FlattenCollectionV8Iteratora",
-          "location": "",
+          ],
+          "declKind": "Struct",
+          "usr": "s:s17FlattenCollectionV5IndexV",
           "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Iterator",
-              "printedName": "FlattenSequence<Base>.Iterator",
-              "usr": "s:s15FlattenSequenceV8IteratorV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s17FlattenCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<FlattenCollection<Base>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "FlattenCollection",
-                  "printedName": "FlattenCollection<Base>",
-                  "usr": "s:s17FlattenCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Base"
-                    }
-                  ]
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "Equatable",
+            "Comparable",
+            "Hashable"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV12makeIterators0A8SequenceV0D0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
+              "kind": "TypeNominal",
               "name": "Iterator",
-              "printedName": "FlattenCollection<Base>.Iterator",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "FlattenSequence<τ_0_0>.Iterator",
-                  "usr": "s:s15FlattenSequenceV8IteratorV"
-                }
-              ]
+              "printedName": "FlattenSequence<τ_0_0>.Iterator",
+              "usr": "s:s15FlattenSequenceV8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV12makeIterators0A8SequenceV0D0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s17FlattenCollectionV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -32540,11 +32507,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FlattenCollectionV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -32552,24 +32514,21 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FlattenCollectionV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FlattenCollectionV19underestimatedCountSivp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "forEach",
           "printedName": "forEach(_:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV7forEachyyy7Element_ADQZKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32579,154 +32538,136 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Base.Element.Element) throws -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element.Element) throws -> ()",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
+                  "kind": "TypeNominal",
                   "name": "Void",
-                  "printedName": "Void",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Void",
-                      "printedName": "()"
-                    }
-                  ]
+                  "printedName": "()"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Base.Element.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Base.Element.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV7forEachyyy7Element_ADQZKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s17FlattenCollectionV10startIndexAB0D0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "FlattenCollection<Base>.Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FlattenCollectionV10startIndexAB0D0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "FlattenCollection<Base>.Index",
+                  "printedName": "FlattenCollection<τ_0_0>.Index",
                   "usr": "s:s17FlattenCollectionV5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FlattenCollectionV10startIndexAB0D0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FlattenCollectionV10startIndexAB0D0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s17FlattenCollectionV8endIndexAB0D0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "FlattenCollection<Base>.Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FlattenCollectionV8endIndexAB0D0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "FlattenCollection<Base>.Index",
+                  "printedName": "FlattenCollection<τ_0_0>.Index",
                   "usr": "s:s17FlattenCollectionV5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FlattenCollectionV8endIndexAB0D0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FlattenCollectionV8endIndexAB0D0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV5index5afterAB5IndexVyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "FlattenCollection<Base>.Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "FlattenCollection<Base>.Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV5index5afterAB5IndexVyx_GAG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV9formIndex5afteryAB0D0Vyx_Gz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32736,23 +32677,22 @@
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "FlattenCollection<Base>.Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV9formIndex5afteryAB0D0Vyx_Gz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV8distance4from2toSiAB5IndexVyx_G_AHtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32763,40 +32703,39 @@
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "FlattenCollection<Base>.Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "FlattenCollection<Base>.Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV8distance4from2toSiAB5IndexVyx_G_AHtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV5index_8offsetByAB5IndexVyx_GAG_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "FlattenCollection<Base>.Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "FlattenCollection<Base>.Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             },
             {
@@ -32805,20 +32744,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV5index_8offsetByAB5IndexVyx_GAG_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV9formIndex_8offsetByyAB0D0Vyx_Gz_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32828,7 +32766,7 @@
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "FlattenCollection<Base>.Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             },
             {
@@ -32837,39 +32775,38 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV9formIndex_8offsetByyAB0D0Vyx_Gz_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV5index_8offsetBy07limitedE0AB5IndexVyx_GSgAH_SiAHtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "FlattenCollection<Base>.Index?",
-              "usr": "s:Sq",
+              "printedName": "Optional<FlattenCollection<τ_0_0>.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "FlattenCollection<Base>.Index",
+                  "printedName": "FlattenCollection<τ_0_0>.Index",
                   "usr": "s:s17FlattenCollectionV5IndexV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "FlattenCollection<Base>.Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             },
             {
@@ -32881,23 +32818,22 @@
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "FlattenCollection<Base>.Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV5index_8offsetBy07limitedE0AB5IndexVyx_GSgAH_SiAHtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV9formIndex_8offsetBy07limitedF0SbAB0D0Vyx_Gz_SiAHtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32908,7 +32844,7 @@
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "FlattenCollection<Base>.Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             },
             {
@@ -32920,100 +32856,122 @@
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "FlattenCollection<Base>.Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV9formIndex_8offsetBy07limitedF0SbAB0D0Vyx_Gz_SiAHtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s17FlattenCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Base.Element.Element"
+              "printedName": "τ_0_0.Element.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
+              "usr": "s:s17FlattenCollectionV5IndexV"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s17FlattenCollectionVy7Element_ACQZAB5IndexVyx_Gcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s17FlattenCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "DefaultIndices",
-              "printedName": "DefaultIndices<FlattenCollection<Base>>",
-              "usr": "s:SI",
+              "name": "Slice",
+              "printedName": "Slice<FlattenCollection<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "FlattenCollection",
-                  "printedName": "FlattenCollection<Base>",
-                  "usr": "s:s17FlattenCollectionV",
+                  "printedName": "FlattenCollection<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Base"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s17FlattenCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<FlattenCollection<τ_0_0>.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "FlattenCollection<τ_0_0>.Index",
+                  "usr": "s:s17FlattenCollectionV5IndexV"
+                }
+              ],
+              "usr": "s:Sn"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s17FlattenCollectionVys5SliceVyAByxGGSnyAB5IndexVyx_GGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionVsSKRzSK7ElementRpzrlE5index6beforeAB5IndexVyx_GAI_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection, Base.Element : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "FlattenCollection<Base>.Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "FlattenCollection<Base>.Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionVsSKRzSK7ElementRpzrlE5index6beforeAB5IndexVyx_GAI_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0.Element : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionVsSKRzSK7ElementRpzrlE9formIndex6beforeyAB0E0Vyx_Gz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection, Base.Element : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -33023,46 +32981,55 @@
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "FlattenCollection<Base>.Index",
+              "printedName": "FlattenCollection<τ_0_0>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionVsSKRzSK7ElementRpzrlE9formIndex6beforeyAB0E0Vyx_Gz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0.Element : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s17FlattenCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element : Collection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "Collection",
+        "BidirectionalCollection"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "FloatingPoint",
       "printedName": "FloatingPoint",
-      "declKind": "Protocol",
-      "usr": "s:SF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Hashable, Self : SignedNumeric, Self : Strideable, Self == Self.Magnitude, Self.Exponent : SignedInteger>",
-      "conformingProtocols": [
-        "SignedNumeric",
-        "Strideable",
-        "Hashable",
-        "Numeric",
-        "Comparable",
-        "Equatable",
-        "ExpressibleByIntegerLiteral"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Exponent",
+          "printedName": "Exponent",
+          "declKind": "AssociatedType",
+          "usr": "s:SF8ExponentQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(sign:exponent:significand:)",
-          "declKind": "Constructor",
-          "usr": "s:SF4sign8exponent11significandxs17FloatingPointSignO_8ExponentQzxtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -33073,263 +33040,56 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Exponent"
+              "printedName": "τ_0_0.Exponent"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SF4sign8exponent11significandxs17FloatingPointSignO_8ExponentQzxtcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(signOf:magnitudeOf:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SF6signOf09magnitudeB0xx_xtcfc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxs5UInt8Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxs4Int8Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxs6UInt16Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxs5Int16Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxs6UInt32Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxs5Int32Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxs6UInt64Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxs5Int64Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxSucfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxSicfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -33337,69 +33097,69 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SFyxSicfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxqd__cSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Source where Self : FloatingPoint, Source : BinaryInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Source"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SFyxqd__cSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FloatingPoint, τ_1_0 : BinaryInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:SF7exactlyxSgqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Source where Self : FloatingPoint, Source : BinaryInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Source"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SF7exactlyxSgqd___tcSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FloatingPoint, τ_1_0 : BinaryInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "radix",
           "printedName": "radix",
-          "declKind": "Var",
-          "usr": "s:SF5radixSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -33411,12 +33171,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF5radixSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -33424,331 +33178,328 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF5radixSivgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF5radixSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "nan",
           "printedName": "nan",
-          "declKind": "Var",
-          "usr": "s:SF3nanxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF3nanxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF3nanxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF3nanxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "signalingNaN",
           "printedName": "signalingNaN",
-          "declKind": "Var",
-          "usr": "s:SF12signalingNaNxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF12signalingNaNxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF12signalingNaNxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF12signalingNaNxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "infinity",
           "printedName": "infinity",
-          "declKind": "Var",
-          "usr": "s:SF8infinityxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF8infinityxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF8infinityxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF8infinityxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "greatestFiniteMagnitude",
           "printedName": "greatestFiniteMagnitude",
-          "declKind": "Var",
-          "usr": "s:SF23greatestFiniteMagnitudexvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF23greatestFiniteMagnitudexvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF23greatestFiniteMagnitudexvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF23greatestFiniteMagnitudexvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "pi",
           "printedName": "pi",
-          "declKind": "Var",
-          "usr": "s:SF2pixvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF2pixvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF2pixvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF2pixvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "ulp",
           "printedName": "ulp",
-          "declKind": "Var",
-          "usr": "s:SF3ulpxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF3ulpxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF3ulpxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF3ulpxvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "ulpOfOne",
           "printedName": "ulpOfOne",
-          "declKind": "Var",
-          "usr": "s:SF8ulpOfOnexvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF8ulpOfOnexvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF8ulpOfOnexvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF8ulpOfOnexvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "leastNormalMagnitude",
           "printedName": "leastNormalMagnitude",
-          "declKind": "Var",
-          "usr": "s:SF20leastNormalMagnitudexvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF20leastNormalMagnitudexvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF20leastNormalMagnitudexvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF20leastNormalMagnitudexvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "leastNonzeroMagnitude",
           "printedName": "leastNonzeroMagnitude",
-          "declKind": "Var",
-          "usr": "s:SF21leastNonzeroMagnitudexvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF21leastNonzeroMagnitudexvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF21leastNonzeroMagnitudexvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF21leastNonzeroMagnitudexvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "sign",
           "printedName": "sign",
-          "declKind": "Var",
-          "usr": "s:SF4signs17FloatingPointSignOvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -33760,11 +33511,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF4signs17FloatingPointSignOvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -33772,126 +33518,406 @@
                   "printedName": "FloatingPointSign",
                   "usr": "s:s17FloatingPointSignO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF4signs17FloatingPointSignOvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF4signs17FloatingPointSignOvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "exponent",
           "printedName": "exponent",
-          "declKind": "Var",
-          "usr": "s:SF8exponent8ExponentQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Exponent"
+              "printedName": "τ_0_0.Exponent"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF8exponent8ExponentQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Exponent"
+                  "printedName": "τ_0_0.Exponent"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF8exponent8ExponentQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF8exponent8ExponentQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "significand",
           "printedName": "significand",
-          "declKind": "Var",
-          "usr": "s:SF11significandxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF11significandxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF11significandxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF11significandxvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF1poiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF2peoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF1sopyxxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Prefix",
+            "Override"
           ]
         },
         {
           "kind": "Function",
           "name": "negate",
           "printedName": "negate()",
-          "declKind": "Func",
-          "usr": "s:SF6negateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF6negateyyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF1soiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF2seoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF1moiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF2meoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF1doiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF2deoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
           "name": "remainder",
           "printedName": "remainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:SF9remainder10dividingByxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DynamicSelf",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF9remainder10dividingByxx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "formRemainder",
           "printedName": "formRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:SF13formRemainder10dividingByyx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -33901,42 +33927,42 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF13formRemainder10dividingByyx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "truncatingRemainder",
           "printedName": "truncatingRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:SF19truncatingRemainder10dividingByxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DynamicSelf",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF19truncatingRemainder10dividingByxx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "formTruncatingRemainder",
           "printedName": "formTruncatingRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:SF23formTruncatingRemainder10dividingByyx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -33946,82 +33972,82 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF23formTruncatingRemainder10dividingByyx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "squareRoot",
           "printedName": "squareRoot()",
-          "declKind": "Func",
-          "usr": "s:SF10squareRootxyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DynamicSelf",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF10squareRootxyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "formSquareRoot",
           "printedName": "formSquareRoot()",
-          "declKind": "Func",
-          "usr": "s:SF14formSquareRootyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF14formSquareRootyyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "addingProduct",
           "printedName": "addingProduct(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SF13addingProductyxx_xtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DynamicSelf",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF13addingProductyxx_xtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "addProduct",
           "printedName": "addProduct(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SF10addProductyyx_xtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -34031,141 +34057,142 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF10addProductyyx_xtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "minimum",
           "printedName": "minimum(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SF7minimumyxx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DynamicSelf",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF7minimumyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "maximum",
           "printedName": "maximum(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SF7maximumyxx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DynamicSelf",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF7maximumyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "minimumMagnitude",
           "printedName": "minimumMagnitude(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SF16minimumMagnitudeyxx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DynamicSelf",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF16minimumMagnitudeyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "maximumMagnitude",
           "printedName": "maximumMagnitude(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SF16maximumMagnitudeyxx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DynamicSelf",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF16maximumMagnitudeyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "rounded",
           "printedName": "rounded(_:)",
-          "declKind": "Func",
-          "usr": "s:SF7roundedyxs25FloatingPointRoundingRuleOF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DynamicSelf",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -34173,18 +34200,17 @@
               "printedName": "FloatingPointRoundingRule",
               "usr": "s:s25FloatingPointRoundingRuleO"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF7roundedyxs25FloatingPointRoundingRuleOF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "round",
           "printedName": "round(_:)",
-          "declKind": "Func",
-          "usr": "s:SF5roundyys25FloatingPointRoundingRuleOF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -34197,83 +34223,82 @@
               "printedName": "FloatingPointRoundingRule",
               "usr": "s:s25FloatingPointRoundingRuleO"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF5roundyys25FloatingPointRoundingRuleOF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Var",
           "name": "nextUp",
           "printedName": "nextUp",
-          "declKind": "Var",
-          "usr": "s:SF6nextUpxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF6nextUpxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF6nextUpxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF6nextUpxvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "nextDown",
           "printedName": "nextDown",
-          "declKind": "Var",
-          "usr": "s:SF8nextDownxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF8nextDownxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF8nextDownxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF8nextDownxvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "isEqual",
           "printedName": "isEqual(to:)",
-          "declKind": "Func",
-          "usr": "s:SF7isEqual2toSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -34284,19 +34309,19 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF7isEqual2toSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "isLess",
           "printedName": "isLess(than:)",
-          "declKind": "Func",
-          "usr": "s:SF6isLess4thanSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -34307,19 +34332,19 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF6isLess4thanSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "isLessThanOrEqualTo",
           "printedName": "isLessThanOrEqualTo(_:)",
-          "declKind": "Func",
-          "usr": "s:SF19isLessThanOrEqualToySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -34330,19 +34355,19 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF19isLessThanOrEqualToySbxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "isTotallyOrdered",
           "printedName": "isTotallyOrdered(belowOrEqualTo:)",
-          "declKind": "Func",
-          "usr": "s:SF16isTotallyOrdered14belowOrEqualToSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -34353,18 +34378,19 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SF16isTotallyOrdered14belowOrEqualToSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "isNormal",
           "printedName": "isNormal",
-          "declKind": "Var",
-          "usr": "s:SF8isNormalSbvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -34376,11 +34402,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF8isNormalSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -34388,18 +34409,22 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF8isNormalSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF8isNormalSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "isFinite",
           "printedName": "isFinite",
-          "declKind": "Var",
-          "usr": "s:SF8isFiniteSbvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -34411,11 +34436,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF8isFiniteSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -34423,18 +34443,22 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF8isFiniteSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF8isFiniteSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "isZero",
           "printedName": "isZero",
-          "declKind": "Var",
-          "usr": "s:SF6isZeroSbvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -34446,11 +34470,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF6isZeroSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -34458,18 +34477,22 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF6isZeroSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF6isZeroSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "isSubnormal",
           "printedName": "isSubnormal",
-          "declKind": "Var",
-          "usr": "s:SF11isSubnormalSbvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -34481,11 +34504,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF11isSubnormalSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -34493,18 +34511,22 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF11isSubnormalSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF11isSubnormalSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "isInfinite",
           "printedName": "isInfinite",
-          "declKind": "Var",
-          "usr": "s:SF10isInfiniteSbvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -34516,11 +34538,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF10isInfiniteSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -34528,18 +34545,22 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF10isInfiniteSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF10isInfiniteSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "isNaN",
           "printedName": "isNaN",
-          "declKind": "Var",
-          "usr": "s:SF5isNaNSbvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -34551,11 +34572,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF5isNaNSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -34563,18 +34579,22 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF5isNaNSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF5isNaNSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "isSignalingNaN",
           "printedName": "isSignalingNaN",
-          "declKind": "Var",
-          "usr": "s:SF14isSignalingNaNSbvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -34586,11 +34606,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF14isSignalingNaNSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -34598,18 +34613,22 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF14isSignalingNaNSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF14isSignalingNaNSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "floatingPointClass",
           "printedName": "floatingPointClass",
-          "declKind": "Var",
-          "usr": "s:SF18floatingPointClasss08FloatingB14ClassificationOvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -34621,11 +34640,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF18floatingPointClasss08FloatingB14ClassificationOvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -34633,18 +34647,22 @@
                   "printedName": "FloatingPointClassification",
                   "usr": "s:s27FloatingPointClassificationO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF18floatingPointClasss08FloatingB14ClassificationOvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SF18floatingPointClasss08FloatingB14ClassificationOvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "isCanonical",
           "printedName": "isCanonical",
-          "declKind": "Var",
-          "usr": "s:SF11isCanonicalSbvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -34656,11 +34674,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF11isCanonicalSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -34668,65 +34681,218 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF11isCanonicalSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF11isCanonicalSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE2eeoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE1loiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE2leoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE1goiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE2geoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "ulpOfOne",
           "printedName": "ulpOfOne",
-          "declKind": "Var",
-          "usr": "s:SFsE8ulpOfOnexvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SFsE8ulpOfOnexvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SFsE8ulpOfOnexvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SFsE8ulpOfOnexvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "rounded",
           "printedName": "rounded(_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE7roundedyxs25FloatingPointRoundingRuleOF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -34734,320 +34900,308 @@
               "printedName": "FloatingPointRoundingRule",
               "usr": "s:s25FloatingPointRoundingRuleO"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE7roundedyxs25FloatingPointRoundingRuleOF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "rounded",
           "printedName": "rounded()",
-          "declKind": "Func",
-          "usr": "s:SFsE7roundedxyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE7roundedxyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "round",
           "printedName": "round()",
-          "declKind": "Func",
-          "usr": "s:SFsE5roundyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE5roundyyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Var",
           "name": "nextDown",
           "printedName": "nextDown",
-          "declKind": "Var",
-          "usr": "s:SFsE8nextDownxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SFsE8nextDownxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SFsE8nextDownxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SFsE8nextDownxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "truncatingRemainder",
           "printedName": "truncatingRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:SFsE19truncatingRemainder10dividingByxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE19truncatingRemainder10dividingByxx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainder",
           "printedName": "remainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:SFsE9remainder10dividingByxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE9remainder10dividingByxx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "squareRoot",
           "printedName": "squareRoot()",
-          "declKind": "Func",
-          "usr": "s:SFsE10squareRootxyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE10squareRootxyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingProduct",
           "printedName": "addingProduct(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE13addingProductyxx_xtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE13addingProductyxx_xtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "minimum",
           "printedName": "minimum(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE7minimumyxx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE7minimumyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "maximum",
           "printedName": "maximum(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE7maximumyxx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE7maximumyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "minimumMagnitude",
           "printedName": "minimumMagnitude(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE16minimumMagnitudeyxx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE16minimumMagnitudeyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "maximumMagnitude",
           "printedName": "maximumMagnitude(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE16maximumMagnitudeyxx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE16maximumMagnitudeyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "floatingPointClass",
           "printedName": "floatingPointClass",
-          "declKind": "Var",
-          "usr": "s:SFsE18floatingPointClasss08FloatingB14ClassificationOvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -35059,11 +35213,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SFsE18floatingPointClasss08FloatingB14ClassificationOvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -35071,289 +35220,44 @@
                   "printedName": "FloatingPointClassification",
                   "usr": "s:s27FloatingPointClassificationO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SFsE18floatingPointClasss08FloatingB14ClassificationOvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FloatingPoint>"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "negated",
-          "printedName": "negated()",
-          "declKind": "Func",
-          "usr": "s:SFsE7negatedxyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Available"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "adding",
-          "printedName": "adding(_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE6addingyxxF",
-          "location": "",
+          "declKind": "Var",
+          "usr": "s:SFsE18floatingPointClasss08FloatingB14ClassificationOvp",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
           "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "add",
-          "printedName": "add(_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE3addyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "subtracting",
-          "printedName": "subtracting(_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE11subtractingyxxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "subtract",
-          "printedName": "subtract(_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE8subtractyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "multiplied",
-          "printedName": "multiplied(by:)",
-          "declKind": "Func",
-          "usr": "s:SFsE10multiplied2byxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "multiply",
-          "printedName": "multiply(by:)",
-          "declKind": "Func",
-          "usr": "s:SFsE8multiply2byyx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "divided",
-          "printedName": "divided(by:)",
-          "declKind": "Func",
-          "usr": "s:SFsE7divided2byxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "divide",
-          "printedName": "divide(by:)",
-          "declKind": "Func",
-          "usr": "s:SFsE6divide2byyx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "abs",
-          "printedName": "abs(_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE3absyxxFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : Hashable, τ_0_0 : SignedNumeric, τ_0_0 : Strideable, τ_0_0 == τ_0_0.Magnitude, τ_0_0.Exponent : SignedInteger>",
+      "conformingProtocols": [
+        "SignedNumeric",
+        "Strideable",
+        "Hashable",
+        "Numeric",
+        "Comparable",
+        "Equatable",
+        "ExpressibleByIntegerLiteral"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "FloatingPointSign",
       "printedName": "FloatingPointSign",
-      "declKind": "Enum",
-      "usr": "s:s17FloatingPointSignO",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable",
-        "RawRepresentable"
-      ],
-      "enumRawTypeName": "Int",
-      "declAttributes": [
-        "Frozen"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "plus",
           "printedName": "plus",
-          "declKind": "EnumElement",
-          "usr": "s:s17FloatingPointSignO4plusyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35368,36 +35272,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointSign.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointSign.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointSign.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointSign",
-                          "printedName": "FloatingPointSign",
-                          "usr": "s:s17FloatingPointSignO"
-                        }
-                      ]
+                      "name": "FloatingPointSign",
+                      "printedName": "FloatingPointSign",
+                      "usr": "s:s17FloatingPointSignO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s17FloatingPointSignO4plusyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0
         },
         {
           "kind": "Var",
           "name": "minus",
           "printedName": "minus",
-          "declKind": "EnumElement",
-          "usr": "s:s17FloatingPointSignO5minusyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35412,45 +35309,34 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointSign.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointSign.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointSign.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointSign",
-                          "printedName": "FloatingPointSign",
-                          "usr": "s:s17FloatingPointSignO"
-                        }
-                      ]
+                      "name": "FloatingPointSign",
+                      "printedName": "FloatingPointSign",
+                      "usr": "s:s17FloatingPointSignO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s17FloatingPointSignO5minusyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(rawValue:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FloatingPointSignO8rawValueABSgSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "FloatingPointSign?",
-              "usr": "s:Sq",
+              "printedName": "Optional<FloatingPointSign>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -35458,7 +35344,8 @@
                   "printedName": "FloatingPointSign",
                   "usr": "s:s17FloatingPointSignO"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -35466,19 +35353,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FloatingPointSignO8rawValueABSgSi_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "rawValue",
           "printedName": "rawValue",
-          "declKind": "Var",
-          "usr": "s:s17FloatingPointSignO8rawValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -35490,10 +35376,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FloatingPointSignO8rawValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -35501,35 +35383,55 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FloatingPointSignO8rawValueSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FloatingPointSignO8rawValueSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "TypeAlias",
-          "name": "RawValue",
-          "printedName": "RawValue",
-          "declKind": "TypeAlias",
-          "usr": "s:s17FloatingPointSignO8RawValuea",
-          "location": "",
-          "moduleName": "Swift",
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointSign",
+              "printedName": "FloatingPointSign",
+              "usr": "s:s17FloatingPointSignO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointSign",
+              "printedName": "FloatingPointSign",
+              "usr": "s:s17FloatingPointSignO"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FloatingPointSignO2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s17FloatingPointSignO9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -35541,10 +35443,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FloatingPointSignO9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -35552,18 +35450,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FloatingPointSignO9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FloatingPointSignO9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s17FloatingPointSignO4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -35576,34 +35478,35 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FloatingPointSignO4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "implicit": true
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s17FloatingPointSignO",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Frozen"
+      ],
+      "enumRawTypeName": "Int",
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable",
+        "RawRepresentable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "FloatingPointClassification",
       "printedName": "FloatingPointClassification",
-      "declKind": "Enum",
-      "usr": "s:s27FloatingPointClassificationO",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable"
-      ],
-      "declAttributes": [
-        "Frozen"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "signalingNaN",
           "printedName": "signalingNaN",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO12signalingNaNyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35618,36 +35521,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointClassification.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointClassification.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointClassification.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointClassification",
-                          "printedName": "FloatingPointClassification",
-                          "usr": "s:s27FloatingPointClassificationO"
-                        }
-                      ]
+                      "name": "FloatingPointClassification",
+                      "printedName": "FloatingPointClassification",
+                      "usr": "s:s27FloatingPointClassificationO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO12signalingNaNyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0
         },
         {
           "kind": "Var",
           "name": "quietNaN",
           "printedName": "quietNaN",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO8quietNaNyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35662,36 +35558,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointClassification.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointClassification.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointClassification.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointClassification",
-                          "printedName": "FloatingPointClassification",
-                          "usr": "s:s27FloatingPointClassificationO"
-                        }
-                      ]
+                      "name": "FloatingPointClassification",
+                      "printedName": "FloatingPointClassification",
+                      "usr": "s:s27FloatingPointClassificationO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO8quietNaNyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1
         },
         {
           "kind": "Var",
           "name": "negativeInfinity",
           "printedName": "negativeInfinity",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO16negativeInfinityyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35706,36 +35595,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointClassification.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointClassification.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointClassification.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointClassification",
-                          "printedName": "FloatingPointClassification",
-                          "usr": "s:s27FloatingPointClassificationO"
-                        }
-                      ]
+                      "name": "FloatingPointClassification",
+                      "printedName": "FloatingPointClassification",
+                      "usr": "s:s27FloatingPointClassificationO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO16negativeInfinityyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 2
         },
         {
           "kind": "Var",
           "name": "negativeNormal",
           "printedName": "negativeNormal",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO14negativeNormalyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35750,36 +35632,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointClassification.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointClassification.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointClassification.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointClassification",
-                          "printedName": "FloatingPointClassification",
-                          "usr": "s:s27FloatingPointClassificationO"
-                        }
-                      ]
+                      "name": "FloatingPointClassification",
+                      "printedName": "FloatingPointClassification",
+                      "usr": "s:s27FloatingPointClassificationO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO14negativeNormalyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 3
         },
         {
           "kind": "Var",
           "name": "negativeSubnormal",
           "printedName": "negativeSubnormal",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO17negativeSubnormalyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35794,36 +35669,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointClassification.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointClassification.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointClassification.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointClassification",
-                          "printedName": "FloatingPointClassification",
-                          "usr": "s:s27FloatingPointClassificationO"
-                        }
-                      ]
+                      "name": "FloatingPointClassification",
+                      "printedName": "FloatingPointClassification",
+                      "usr": "s:s27FloatingPointClassificationO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO17negativeSubnormalyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 4
         },
         {
           "kind": "Var",
           "name": "negativeZero",
           "printedName": "negativeZero",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO12negativeZeroyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35838,36 +35706,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointClassification.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointClassification.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointClassification.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointClassification",
-                          "printedName": "FloatingPointClassification",
-                          "usr": "s:s27FloatingPointClassificationO"
-                        }
-                      ]
+                      "name": "FloatingPointClassification",
+                      "printedName": "FloatingPointClassification",
+                      "usr": "s:s27FloatingPointClassificationO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO12negativeZeroyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 5
         },
         {
           "kind": "Var",
           "name": "positiveZero",
           "printedName": "positiveZero",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO12positiveZeroyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35882,36 +35743,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointClassification.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointClassification.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointClassification.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointClassification",
-                          "printedName": "FloatingPointClassification",
-                          "usr": "s:s27FloatingPointClassificationO"
-                        }
-                      ]
+                      "name": "FloatingPointClassification",
+                      "printedName": "FloatingPointClassification",
+                      "usr": "s:s27FloatingPointClassificationO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO12positiveZeroyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 6
         },
         {
           "kind": "Var",
           "name": "positiveSubnormal",
           "printedName": "positiveSubnormal",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO17positiveSubnormalyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35926,36 +35780,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointClassification.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointClassification.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointClassification.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointClassification",
-                          "printedName": "FloatingPointClassification",
-                          "usr": "s:s27FloatingPointClassificationO"
-                        }
-                      ]
+                      "name": "FloatingPointClassification",
+                      "printedName": "FloatingPointClassification",
+                      "usr": "s:s27FloatingPointClassificationO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO17positiveSubnormalyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 7
         },
         {
           "kind": "Var",
           "name": "positiveNormal",
           "printedName": "positiveNormal",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO14positiveNormalyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35970,36 +35817,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointClassification.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointClassification.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointClassification.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointClassification",
-                          "printedName": "FloatingPointClassification",
-                          "usr": "s:s27FloatingPointClassificationO"
-                        }
-                      ]
+                      "name": "FloatingPointClassification",
+                      "printedName": "FloatingPointClassification",
+                      "usr": "s:s27FloatingPointClassificationO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO14positiveNormalyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 8
         },
         {
           "kind": "Var",
           "name": "positiveInfinity",
           "printedName": "positiveInfinity",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO16positiveInfinityyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -36014,36 +35854,62 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointClassification.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointClassification.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointClassification.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointClassification",
-                          "printedName": "FloatingPointClassification",
-                          "usr": "s:s27FloatingPointClassificationO"
-                        }
-                      ]
+                      "name": "FloatingPointClassification",
+                      "printedName": "FloatingPointClassification",
+                      "usr": "s:s27FloatingPointClassificationO"
                     }
                   ]
                 }
               ]
             }
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO16positiveInfinityyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 9
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointClassification",
+              "printedName": "FloatingPointClassification",
+              "usr": "s:s27FloatingPointClassificationO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointClassification",
+              "printedName": "FloatingPointClassification",
+              "usr": "s:s27FloatingPointClassificationO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s27FloatingPointClassificationO2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "implicit": true,
+          "declAttributes": [
+            "Infix"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s27FloatingPointClassificationO9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -36055,10 +35921,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s27FloatingPointClassificationO9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -36066,18 +35928,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s27FloatingPointClassificationO9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s27FloatingPointClassificationO9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s27FloatingPointClassificationO4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -36090,31 +35956,33 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s27FloatingPointClassificationO4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "implicit": true
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s27FloatingPointClassificationO",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Frozen"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "FloatingPointRoundingRule",
       "printedName": "FloatingPointRoundingRule",
-      "declKind": "Enum",
-      "usr": "s:s25FloatingPointRoundingRuleO",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "toNearestOrAwayFromZero",
           "printedName": "toNearestOrAwayFromZero",
-          "declKind": "EnumElement",
-          "usr": "s:s25FloatingPointRoundingRuleO23toNearestOrAwayFromZeroyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -36129,36 +35997,28 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointRoundingRule.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointRoundingRule.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointRoundingRule.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointRoundingRule",
-                          "printedName": "FloatingPointRoundingRule",
-                          "usr": "s:s25FloatingPointRoundingRuleO"
-                        }
-                      ]
+                      "name": "FloatingPointRoundingRule",
+                      "printedName": "FloatingPointRoundingRule",
+                      "usr": "s:s25FloatingPointRoundingRuleO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s25FloatingPointRoundingRuleO23toNearestOrAwayFromZeroyA2BmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "toNearestOrEven",
           "printedName": "toNearestOrEven",
-          "declKind": "EnumElement",
-          "usr": "s:s25FloatingPointRoundingRuleO15toNearestOrEvenyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -36173,36 +36033,28 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointRoundingRule.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointRoundingRule.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointRoundingRule.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointRoundingRule",
-                          "printedName": "FloatingPointRoundingRule",
-                          "usr": "s:s25FloatingPointRoundingRuleO"
-                        }
-                      ]
+                      "name": "FloatingPointRoundingRule",
+                      "printedName": "FloatingPointRoundingRule",
+                      "usr": "s:s25FloatingPointRoundingRuleO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s25FloatingPointRoundingRuleO15toNearestOrEvenyA2BmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "up",
           "printedName": "up",
-          "declKind": "EnumElement",
-          "usr": "s:s25FloatingPointRoundingRuleO2upyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -36217,36 +36069,28 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointRoundingRule.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointRoundingRule.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointRoundingRule.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointRoundingRule",
-                          "printedName": "FloatingPointRoundingRule",
-                          "usr": "s:s25FloatingPointRoundingRuleO"
-                        }
-                      ]
+                      "name": "FloatingPointRoundingRule",
+                      "printedName": "FloatingPointRoundingRule",
+                      "usr": "s:s25FloatingPointRoundingRuleO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s25FloatingPointRoundingRuleO2upyA2BmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "down",
           "printedName": "down",
-          "declKind": "EnumElement",
-          "usr": "s:s25FloatingPointRoundingRuleO4downyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -36261,36 +36105,28 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointRoundingRule.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointRoundingRule.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointRoundingRule.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointRoundingRule",
-                          "printedName": "FloatingPointRoundingRule",
-                          "usr": "s:s25FloatingPointRoundingRuleO"
-                        }
-                      ]
+                      "name": "FloatingPointRoundingRule",
+                      "printedName": "FloatingPointRoundingRule",
+                      "usr": "s:s25FloatingPointRoundingRuleO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s25FloatingPointRoundingRuleO4downyA2BmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "towardZero",
           "printedName": "towardZero",
-          "declKind": "EnumElement",
-          "usr": "s:s25FloatingPointRoundingRuleO10towardZeroyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -36305,36 +36141,28 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointRoundingRule.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointRoundingRule.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointRoundingRule.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointRoundingRule",
-                          "printedName": "FloatingPointRoundingRule",
-                          "usr": "s:s25FloatingPointRoundingRuleO"
-                        }
-                      ]
+                      "name": "FloatingPointRoundingRule",
+                      "printedName": "FloatingPointRoundingRule",
+                      "usr": "s:s25FloatingPointRoundingRuleO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s25FloatingPointRoundingRuleO10towardZeroyA2BmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "awayFromZero",
           "printedName": "awayFromZero",
-          "declKind": "EnumElement",
-          "usr": "s:s25FloatingPointRoundingRuleO12awayFromZeroyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -36349,36 +36177,61 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(FloatingPointRoundingRule.Type)",
+                  "name": "Metatype",
+                  "printedName": "FloatingPointRoundingRule.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "FloatingPointRoundingRule.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "FloatingPointRoundingRule",
-                          "printedName": "FloatingPointRoundingRule",
-                          "usr": "s:s25FloatingPointRoundingRuleO"
-                        }
-                      ]
+                      "name": "FloatingPointRoundingRule",
+                      "printedName": "FloatingPointRoundingRule",
+                      "usr": "s:s25FloatingPointRoundingRuleO"
                     }
                   ]
                 }
               ]
             }
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s25FloatingPointRoundingRuleO12awayFromZeroyA2BmF",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointRoundingRule",
+              "printedName": "FloatingPointRoundingRule",
+              "usr": "s:s25FloatingPointRoundingRuleO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointRoundingRule",
+              "printedName": "FloatingPointRoundingRule",
+              "usr": "s:s25FloatingPointRoundingRuleO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25FloatingPointRoundingRuleO2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "implicit": true,
+          "declAttributes": [
+            "Infix"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s25FloatingPointRoundingRuleO9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -36390,10 +36243,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s25FloatingPointRoundingRuleO9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -36401,18 +36250,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25FloatingPointRoundingRuleO9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s25FloatingPointRoundingRuleO9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s25FloatingPointRoundingRuleO4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -36425,19 +36278,748 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s25FloatingPointRoundingRuleO4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "implicit": true
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s25FloatingPointRoundingRuleO",
+      "moduleName": "Swift",
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "BinaryFloatingPoint",
       "printedName": "BinaryFloatingPoint",
+      "children": [
+        {
+          "kind": "AssociatedType",
+          "name": "RawSignificand",
+          "printedName": "RawSignificand",
+          "declKind": "AssociatedType",
+          "usr": "s:SB14RawSignificandQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "RawExponent",
+          "printedName": "RawExponent",
+          "declKind": "AssociatedType",
+          "usr": "s:SB11RawExponentQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(sign:exponentBitPattern:significandBitPattern:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointSign",
+              "printedName": "FloatingPointSign",
+              "usr": "s:s17FloatingPointSignO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.RawExponent"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.RawSignificand"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SB4sign18exponentBitPattern011significandcD0xs17FloatingPointSignO_11RawExponentQz0I11SignificandQztcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryFloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SByxSfcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryFloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SByxSdcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryFloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SByxs7Float80Vcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryFloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SByxqd__cSBRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryFloatingPoint, τ_1_0 : BinaryFloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SB7exactlyxSgqd___tcSBRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryFloatingPoint, τ_1_0 : BinaryFloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "exponentBitCount",
+          "printedName": "exponentBitCount",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SB16exponentBitCountSivgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BinaryFloatingPoint>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SB16exponentBitCountSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "significandBitCount",
+          "printedName": "significandBitCount",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SB19significandBitCountSivgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BinaryFloatingPoint>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SB19significandBitCountSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "exponentBitPattern",
+          "printedName": "exponentBitPattern",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.RawExponent"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.RawExponent"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SB18exponentBitPattern11RawExponentQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BinaryFloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SB18exponentBitPattern11RawExponentQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "significandBitPattern",
+          "printedName": "significandBitPattern",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.RawSignificand"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.RawSignificand"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SB21significandBitPattern14RawSignificandQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BinaryFloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SB21significandBitPattern14RawSignificandQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "binade",
+          "printedName": "binade",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SB6binadexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BinaryFloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SB6binadexvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "significandWidth",
+          "printedName": "significandWidth",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SB16significandWidthSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BinaryFloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SB16significandWidthSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "radix",
+          "printedName": "radix",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SBsE5radixSivgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BinaryFloatingPoint>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SBsE5radixSivpZ",
+          "moduleName": "Swift",
+          "static": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(signOf:magnitudeOf:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SBsE6signOf09magnitudeB0xx_xtcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryFloatingPoint>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SBsEyxqd__cSBRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryFloatingPoint, τ_1_0 : BinaryFloatingPoint>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SBsE7exactlyxSgqd___tcSBRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryFloatingPoint, τ_1_0 : BinaryFloatingPoint>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isTotallyOrdered",
+          "printedName": "isTotallyOrdered(belowOrEqualTo:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SBsE16isTotallyOrdered14belowOrEqualToSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryFloatingPoint>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlEyxqd__cSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryFloatingPoint, τ_1_0 : BinaryInteger, τ_0_0.RawSignificand : FixedWidthInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlE7exactlyxSgqd___tcSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryFloatingPoint, τ_1_0 : BinaryInteger, τ_0_0.RawSignificand : FixedWidthInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "random",
+          "printedName": "random(in:using:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlE6random2in5usingxSnyxG_qd__ztSGRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryFloatingPoint, τ_1_0 : RandomNumberGenerator, τ_0_0.RawSignificand : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "random",
+          "printedName": "random(in:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlE6random2inxSnyxG_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryFloatingPoint, τ_0_0.RawSignificand : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "random",
+          "printedName": "random(in:using:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SN"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlE6random2in5usingxSNyxG_qd__ztSGRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryFloatingPoint, τ_1_0 : RandomNumberGenerator, τ_0_0.RawSignificand : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "random",
+          "printedName": "random(in:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SN"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlE6random2inxSNyxG_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryFloatingPoint, τ_0_0.RawSignificand : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        }
+      ],
       "declKind": "Protocol",
       "usr": "s:SB",
-      "location": "",
       "moduleName": "Swift",
-      "genericSig": "<Self : ExpressibleByFloatLiteral, Self : FloatingPoint, Self.RawExponent : UnsignedInteger, Self.RawSignificand : UnsignedInteger>",
+      "genericSig": "<τ_0_0 : ExpressibleByFloatLiteral, τ_0_0 : FloatingPoint, τ_0_0.RawExponent : UnsignedInteger, τ_0_0.RawSignificand : UnsignedInteger>",
       "conformingProtocols": [
         "FloatingPoint",
         "ExpressibleByFloatLiteral",
@@ -36448,738 +37030,2364 @@
         "Comparable",
         "Equatable",
         "ExpressibleByIntegerLiteral"
-      ],
-      "children": [
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(sign:exponentBitPattern:significandBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:SB4sign18exponentBitPattern011significandcD0xs17FloatingPointSignO_11RawExponentQz0I11SignificandQztcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryFloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "FloatingPointSign",
-              "printedName": "FloatingPointSign",
-              "usr": "s:s17FloatingPointSignO"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.RawExponent"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.RawSignificand"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SByxSfcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryFloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SByxSdcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryFloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SByxs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryFloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SByxqd__cSBRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Source where Self : BinaryFloatingPoint, Source : BinaryFloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Source"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:SB7exactlyxSgqd___tcSBRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Source where Self : BinaryFloatingPoint, Source : BinaryFloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Source"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "exponentBitCount",
-          "printedName": "exponentBitCount",
-          "declKind": "Var",
-          "usr": "s:SB16exponentBitCountSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SB16exponentBitCountSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryFloatingPoint>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "significandBitCount",
-          "printedName": "significandBitCount",
-          "declKind": "Var",
-          "usr": "s:SB19significandBitCountSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SB19significandBitCountSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryFloatingPoint>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "exponentBitPattern",
-          "printedName": "exponentBitPattern",
-          "declKind": "Var",
-          "usr": "s:SB18exponentBitPattern11RawExponentQzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.RawExponent"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SB18exponentBitPattern11RawExponentQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryFloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.RawExponent"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "significandBitPattern",
-          "printedName": "significandBitPattern",
-          "declKind": "Var",
-          "usr": "s:SB21significandBitPattern14RawSignificandQzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.RawSignificand"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SB21significandBitPattern14RawSignificandQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryFloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.RawSignificand"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "binade",
-          "printedName": "binade",
-          "declKind": "Var",
-          "usr": "s:SB6binadexvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SB6binadexvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryFloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "significandWidth",
-          "printedName": "significandWidth",
-          "declKind": "Var",
-          "usr": "s:SB16significandWidthSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SB16significandWidthSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryFloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "radix",
-          "printedName": "radix",
-          "declKind": "Var",
-          "usr": "s:SBsE5radixSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SBsE5radixSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryFloatingPoint>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(signOf:magnitudeOf:)",
-          "declKind": "Constructor",
-          "usr": "s:SBsE6signOf09magnitudeB0xx_xtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryFloatingPoint>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SBsEyxqd__cSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Source where Self : BinaryFloatingPoint, Source : BinaryInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Source"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:SBsE7exactlyxSgqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Source where Self : BinaryFloatingPoint, Source : BinaryInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Source"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SBsEyxqd__cSBRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Source where Self : BinaryFloatingPoint, Source : BinaryFloatingPoint>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Source"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:SBsE7exactlyxSgqd___tcSBRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Source where Self : BinaryFloatingPoint, Source : BinaryFloatingPoint>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Source"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isTotallyOrdered",
-          "printedName": "isTotallyOrdered(belowOrEqualTo:)",
-          "declKind": "Func",
-          "usr": "s:SBsE16isTotallyOrdered14belowOrEqualToSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryFloatingPoint>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "random",
-          "printedName": "random(in:using:)",
-          "declKind": "Func",
-          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlE6random2in5usingxSnyxG_qd__ztSGRd__lFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : BinaryFloatingPoint, T : RandomNumberGenerator, Self.RawSignificand : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Self>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "random",
-          "printedName": "random(in:)",
-          "declKind": "Func",
-          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlE6random2inxSnyxG_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryFloatingPoint, Self.RawSignificand : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Self>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "random",
-          "printedName": "random(in:using:)",
-          "declKind": "Func",
-          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlE6random2in5usingxSNyxG_qd__ztSGRd__lFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : BinaryFloatingPoint, T : RandomNumberGenerator, Self.RawSignificand : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "ClosedRange",
-              "printedName": "ClosedRange<Self>",
-              "usr": "s:SN",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "random",
-          "printedName": "random(in:)",
-          "declKind": "Func",
-          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlE6random2inxSNyxG_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryFloatingPoint, Self.RawSignificand : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "ClosedRange",
-              "printedName": "ClosedRange<Self>",
-              "usr": "s:SN",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        }
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Float",
       "printedName": "Float",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_value",
+          "printedName": "_value",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "BuiltinFloat",
+              "printedName": "Builtin.FPIEEE32"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinFloat",
+                  "printedName": "Builtin.FPIEEE32"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf6_valueBf32_vg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinFloat",
+                  "printedName": "Builtin.FPIEEE32"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf6_valueBf32_vs",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf6_valueBf32_vp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:S2fycfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf4fromSfs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Float>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SfySfSgxcSyRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : StringProtocol>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "description",
+          "printedName": "description",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf11descriptionSSvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf16debugDescriptionSSvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "exponentBitCount",
+          "printedName": "exponentBitCount",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf16exponentBitCountSivgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf16exponentBitCountSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "significandBitCount",
+          "printedName": "significandBitCount",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf19significandBitCountSivgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf19significandBitCountSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "bitPattern",
+          "printedName": "bitPattern",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt32",
+                  "printedName": "UInt32",
+                  "usr": "s:s6UInt32V"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf10bitPatterns6UInt32Vvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf10bitPatterns6UInt32Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(bitPattern:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf10bitPatternSfs6UInt32V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "sign",
+          "printedName": "sign",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointSign",
+              "printedName": "FloatingPointSign",
+              "usr": "s:s17FloatingPointSignO"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "FloatingPointSign",
+                  "printedName": "FloatingPointSign",
+                  "usr": "s:s17FloatingPointSignO"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf4signs17FloatingPointSignOvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf4signs17FloatingPointSignOvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "exponentBitPattern",
+          "printedName": "exponentBitPattern",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf18exponentBitPatternSuvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf18exponentBitPatternSuvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "significandBitPattern",
+          "printedName": "significandBitPattern",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt32",
+                  "printedName": "UInt32",
+                  "usr": "s:s6UInt32V"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf21significandBitPatterns6UInt32Vvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf21significandBitPatterns6UInt32Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(sign:exponentBitPattern:significandBitPattern:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointSign",
+              "printedName": "FloatingPointSign",
+              "usr": "s:s17FloatingPointSignO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf4sign18exponentBitPattern011significandcD0Sfs17FloatingPointSignO_Sus6UInt32Vtcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isCanonical",
+          "printedName": "isCanonical",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf11isCanonicalSbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf11isCanonicalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "infinity",
+          "printedName": "infinity",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf8infinitySfvgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf8infinitySfvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "nan",
+          "printedName": "nan",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf3nanSfvgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf3nanSfvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "signalingNaN",
+          "printedName": "signalingNaN",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf12signalingNaNSfvgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf12signalingNaNSfvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "greatestFiniteMagnitude",
+          "printedName": "greatestFiniteMagnitude",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf23greatestFiniteMagnitudeSfvgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf23greatestFiniteMagnitudeSfvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "pi",
+          "printedName": "pi",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf2piSfvgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf2piSfvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "ulp",
+          "printedName": "ulp",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf3ulpSfvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf3ulpSfvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "leastNormalMagnitude",
+          "printedName": "leastNormalMagnitude",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf20leastNormalMagnitudeSfvgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf20leastNormalMagnitudeSfvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "leastNonzeroMagnitude",
+          "printedName": "leastNonzeroMagnitude",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf21leastNonzeroMagnitudeSfvgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf21leastNonzeroMagnitudeSfvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "ulpOfOne",
+          "printedName": "ulpOfOne",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf8ulpOfOneSfvgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf8ulpOfOneSfvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "exponent",
+          "printedName": "exponent",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf8exponentSivg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf8exponentSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "significand",
+          "printedName": "significand",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf11significandSfvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf11significandSfvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(sign:exponent:significand:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointSign",
+              "printedName": "FloatingPointSign",
+              "usr": "s:s17FloatingPointSignO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf4sign8exponent11significandSfs17FloatingPointSignO_SiSftcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(nan:signaling:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf3nan9signalingSfs6UInt32V_Sbtcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "nextUp",
+          "printedName": "nextUp",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf6nextUpSfvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf6nextUpSfvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "round",
+          "printedName": "round(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointRoundingRule",
+              "printedName": "FloatingPointRoundingRule",
+              "usr": "s:s25FloatingPointRoundingRuleO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf5roundyys25FloatingPointRoundingRuleOF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "negate",
+          "printedName": "negate()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf6negateyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf2peoiyySfz_SftFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf2seoiyySfz_SftFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf2meoiyySfz_SftFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf2deoiyySfz_SftFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formRemainder",
+          "printedName": "formRemainder(dividingBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf13formRemainder10dividingByySf_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "formTruncatingRemainder",
+          "printedName": "formTruncatingRemainder(dividingBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf23formTruncatingRemainder10dividingByySf_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "formSquareRoot",
+          "printedName": "formSquareRoot()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf14formSquareRootyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "addProduct",
+          "printedName": "addProduct(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf10addProductyySf_SftF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "isEqual",
+          "printedName": "isEqual(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf7isEqual2toSbSf_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isLess",
+          "printedName": "isLess(than:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf6isLess4thanSbSf_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isLessThanOrEqualTo",
+          "printedName": "isLessThanOrEqualTo(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf19isLessThanOrEqualToySbSfF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isNormal",
+          "printedName": "isNormal",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf8isNormalSbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf8isNormalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isFinite",
+          "printedName": "isFinite",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf8isFiniteSbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf8isFiniteSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isZero",
+          "printedName": "isZero",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf6isZeroSbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf6isZeroSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isSubnormal",
+          "printedName": "isSubnormal",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf11isSubnormalSbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf11isSubnormalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isInfinite",
+          "printedName": "isInfinite",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf10isInfiniteSbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf10isInfiniteSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isNaN",
+          "printedName": "isNaN",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf5isNaNSbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf5isNaNSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isSignalingNaN",
+          "printedName": "isSignalingNaN",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf14isSignalingNaNSbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf14isSignalingNaNSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "binade",
+          "printedName": "binade",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf6binadeSfvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf6binadeSfvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "significandWidth",
+          "printedName": "significandWidth",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf16significandWidthSivg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf16significandWidthSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(floatLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf12floatLiteralS2f_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(integerLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf14integerLiteralSfs5Int64V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "hash",
+          "printedName": "hash(into:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Hasher",
+              "printedName": "Hasher",
+              "usr": "s:s6HasherV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "hashValue",
+          "printedName": "hashValue",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Var",
+          "name": "magnitude",
+          "printedName": "magnitude",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf9magnitudeSfvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf9magnitudeSfvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf1sopyS2fFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SfySfSicfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SfySfxcSzRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SfyS2fcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Float>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf7exactlySfSgSf_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SfySfSdcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Float>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf7exactlySfSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SfySfs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Float>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf7exactlySfSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf1poiyS2f_SftFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf1soiyS2f_SftFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf1moiyS2f_SftFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf1doiyS2f_SftFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf8distance2toS2f_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "advanced",
+          "printedName": "advanced(by:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf8advanced2byS2f_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "customMirror",
+          "printedName": "customMirror",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Mirror",
+              "printedName": "Mirror",
+              "usr": "s:s6MirrorV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf12customMirrors0B0Vvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf12customMirrors0B0Vvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "customPlaygroundQuickLook",
+          "printedName": "customPlaygroundQuickLook",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "_PlaygroundQuickLook",
+              "printedName": "_PlaygroundQuickLook",
+              "usr": "s:s20_PlaygroundQuickLookO"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_PlaygroundQuickLook",
+                  "printedName": "_PlaygroundQuickLook",
+                  "usr": "s:s20_PlaygroundQuickLookO"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
+          ]
+        }
+      ],
       "declKind": "Struct",
       "usr": "s:Sf",
-      "location": "",
       "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
-        "Decodable",
         "Encodable",
+        "Decodable",
         "LosslessStringConvertible",
         "CustomStringConvertible",
         "CustomDebugStringConvertible",
@@ -37201,2816 +39409,2364 @@
         "_CVarArgPassedAsDouble",
         "_CVarArgAligned",
         "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:S2fycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf4fromSfs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:Sf6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfSgxcSyRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : StringProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "description",
-          "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:Sf11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "debugDescription",
-          "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Sf16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Magnitude",
-          "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:Sf9Magnitudea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Exponent",
-          "printedName": "Exponent",
-          "declKind": "TypeAlias",
-          "usr": "s:Sf8Exponenta",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "RawSignificand",
-          "printedName": "RawSignificand",
-          "declKind": "TypeAlias",
-          "usr": "s:Sf14RawSignificanda",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "exponentBitCount",
-          "printedName": "exponentBitCount",
-          "declKind": "Var",
-          "usr": "s:Sf16exponentBitCountSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf16exponentBitCountSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "significandBitCount",
-          "printedName": "significandBitCount",
-          "declKind": "Var",
-          "usr": "s:Sf19significandBitCountSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf19significandBitCountSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "bitPattern",
-          "printedName": "bitPattern",
-          "declKind": "Var",
-          "usr": "s:Sf10bitPatterns6UInt32Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf10bitPatterns6UInt32Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt32",
-                  "printedName": "UInt32",
-                  "usr": "s:s6UInt32V"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf10bitPatternSfs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "sign",
-          "printedName": "sign",
-          "declKind": "Var",
-          "usr": "s:Sf4signs17FloatingPointSignOvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "FloatingPointSign",
-              "printedName": "FloatingPointSign",
-              "usr": "s:s17FloatingPointSignO"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf4signs17FloatingPointSignOvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "FloatingPointSign",
-                  "printedName": "FloatingPointSign",
-                  "usr": "s:s17FloatingPointSignO"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "exponentBitPattern",
-          "printedName": "exponentBitPattern",
-          "declKind": "Var",
-          "usr": "s:Sf18exponentBitPatternSuvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf18exponentBitPatternSuvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt",
-                  "printedName": "UInt",
-                  "usr": "s:Su"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "significandBitPattern",
-          "printedName": "significandBitPattern",
-          "declKind": "Var",
-          "usr": "s:Sf21significandBitPatterns6UInt32Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf21significandBitPatterns6UInt32Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt32",
-                  "printedName": "UInt32",
-                  "usr": "s:s6UInt32V"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(sign:exponentBitPattern:significandBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf4sign18exponentBitPattern011significandcD0Sfs17FloatingPointSignO_Sus6UInt32Vtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "FloatingPointSign",
-              "printedName": "FloatingPointSign",
-              "usr": "s:s17FloatingPointSignO"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isCanonical",
-          "printedName": "isCanonical",
-          "declKind": "Var",
-          "usr": "s:Sf11isCanonicalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf11isCanonicalSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "infinity",
-          "printedName": "infinity",
-          "declKind": "Var",
-          "usr": "s:Sf8infinitySfvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf8infinitySfvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "nan",
-          "printedName": "nan",
-          "declKind": "Var",
-          "usr": "s:Sf3nanSfvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf3nanSfvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "signalingNaN",
-          "printedName": "signalingNaN",
-          "declKind": "Var",
-          "usr": "s:Sf12signalingNaNSfvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf12signalingNaNSfvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "greatestFiniteMagnitude",
-          "printedName": "greatestFiniteMagnitude",
-          "declKind": "Var",
-          "usr": "s:Sf23greatestFiniteMagnitudeSfvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf23greatestFiniteMagnitudeSfvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "pi",
-          "printedName": "pi",
-          "declKind": "Var",
-          "usr": "s:Sf2piSfvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf2piSfvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "ulp",
-          "printedName": "ulp",
-          "declKind": "Var",
-          "usr": "s:Sf3ulpSfvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf3ulpSfvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "leastNormalMagnitude",
-          "printedName": "leastNormalMagnitude",
-          "declKind": "Var",
-          "usr": "s:Sf20leastNormalMagnitudeSfvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf20leastNormalMagnitudeSfvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "leastNonzeroMagnitude",
-          "printedName": "leastNonzeroMagnitude",
-          "declKind": "Var",
-          "usr": "s:Sf21leastNonzeroMagnitudeSfvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf21leastNonzeroMagnitudeSfvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "ulpOfOne",
-          "printedName": "ulpOfOne",
-          "declKind": "Var",
-          "usr": "s:Sf8ulpOfOneSfvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf8ulpOfOneSfvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "exponent",
-          "printedName": "exponent",
-          "declKind": "Var",
-          "usr": "s:Sf8exponentSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf8exponentSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "significand",
-          "printedName": "significand",
-          "declKind": "Var",
-          "usr": "s:Sf11significandSfvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf11significandSfvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(sign:exponent:significand:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf4sign8exponent11significandSfs17FloatingPointSignO_SiSftcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "FloatingPointSign",
-              "printedName": "FloatingPointSign",
-              "usr": "s:s17FloatingPointSignO"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(nan:signaling:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf3nan9signalingSfs6UInt32V_Sbtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "RawSignificand",
-              "printedName": "Float.RawSignificand",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt32",
-                  "printedName": "UInt32",
-                  "usr": "s:s6UInt32V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "nextUp",
-          "printedName": "nextUp",
-          "declKind": "Var",
-          "usr": "s:Sf6nextUpSfvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf6nextUpSfvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "round",
-          "printedName": "round(_:)",
-          "declKind": "Func",
-          "usr": "s:Sf5roundyys25FloatingPointRoundingRuleOF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "FloatingPointRoundingRule",
-              "printedName": "FloatingPointRoundingRule",
-              "usr": "s:s25FloatingPointRoundingRuleO"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "negate",
-          "printedName": "negate()",
-          "declKind": "Func",
-          "usr": "s:Sf6negateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formRemainder",
-          "printedName": "formRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:Sf13formRemainder10dividingByySf_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formTruncatingRemainder",
-          "printedName": "formTruncatingRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:Sf23formTruncatingRemainder10dividingByySf_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formSquareRoot",
-          "printedName": "formSquareRoot()",
-          "declKind": "Func",
-          "usr": "s:Sf14formSquareRootyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "addProduct",
-          "printedName": "addProduct(_:_:)",
-          "declKind": "Func",
-          "usr": "s:Sf10addProductyySf_SftF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isEqual",
-          "printedName": "isEqual(to:)",
-          "declKind": "Func",
-          "usr": "s:Sf7isEqual2toSbSf_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isLess",
-          "printedName": "isLess(than:)",
-          "declKind": "Func",
-          "usr": "s:Sf6isLess4thanSbSf_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isLessThanOrEqualTo",
-          "printedName": "isLessThanOrEqualTo(_:)",
-          "declKind": "Func",
-          "usr": "s:Sf19isLessThanOrEqualToySbSfF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isNormal",
-          "printedName": "isNormal",
-          "declKind": "Var",
-          "usr": "s:Sf8isNormalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf8isNormalSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isFinite",
-          "printedName": "isFinite",
-          "declKind": "Var",
-          "usr": "s:Sf8isFiniteSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf8isFiniteSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isZero",
-          "printedName": "isZero",
-          "declKind": "Var",
-          "usr": "s:Sf6isZeroSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf6isZeroSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isSubnormal",
-          "printedName": "isSubnormal",
-          "declKind": "Var",
-          "usr": "s:Sf11isSubnormalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf11isSubnormalSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isInfinite",
-          "printedName": "isInfinite",
-          "declKind": "Var",
-          "usr": "s:Sf10isInfiniteSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf10isInfiniteSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isNaN",
-          "printedName": "isNaN",
-          "declKind": "Var",
-          "usr": "s:Sf5isNaNSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf5isNaNSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isSignalingNaN",
-          "printedName": "isSignalingNaN",
-          "declKind": "Var",
-          "usr": "s:Sf14isSignalingNaNSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf14isSignalingNaNSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "binade",
-          "printedName": "binade",
-          "declKind": "Var",
-          "usr": "s:Sf6binadeSfvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf6binadeSfvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "significandWidth",
-          "printedName": "significandWidth",
-          "declKind": "Var",
-          "usr": "s:Sf16significandWidthSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf16significandWidthSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(floatLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf12floatLiteralS2f_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "FloatLiteralType",
-          "printedName": "FloatLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Sf16FloatLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "RawExponent",
-          "printedName": "RawExponent",
-          "declKind": "TypeAlias",
-          "usr": "s:Sf11RawExponenta",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(integerLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf14integerLiteralSfs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "IntegerLiteralType",
-          "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Sf18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "hash",
-          "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:Sf4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Hasher",
-              "printedName": "Hasher",
-              "usr": "s:s6HasherV"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "hashValue",
-          "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Sf9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "magnitude",
-          "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:Sf9magnitudeSfvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf9magnitudeSfvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs5UInt8Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs5UInt8V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs4Int8Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs4Int8V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs6UInt16Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs6UInt16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs5Int16Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs5Int16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs6UInt32Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs5Int32Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs5Int32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs6UInt64Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs5Int64Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfSucfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfSicfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfyS2fcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgSf_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfSdcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(to:)",
-          "declKind": "Func",
-          "usr": "s:Sf8distance2toS2f_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "advanced",
-          "printedName": "advanced(by:)",
-          "declKind": "Func",
-          "usr": "s:Sf8advanced2byS2f_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:Sf6Stridea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Sf12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customPlaygroundQuickLook",
-          "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:Sf25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "_PlaygroundQuickLook",
-              "printedName": "_PlaygroundQuickLook",
-              "usr": "s:s20_PlaygroundQuickLookO"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "_PlaygroundQuickLook",
-                  "printedName": "_PlaygroundQuickLook",
-                  "usr": "s:s20_PlaygroundQuickLookO"
-                }
-              ]
-            }
-          ]
-        }
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Double",
       "printedName": "Double",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_value",
+          "printedName": "_value",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "BuiltinFloat",
+              "printedName": "Builtin.FPIEEE64"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinFloat",
+                  "printedName": "Builtin.FPIEEE64"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd6_valueBf64_vg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinFloat",
+                  "printedName": "Builtin.FPIEEE64"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd6_valueBf64_vs",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd6_valueBf64_vp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:S2dycfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd4fromSds7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Double>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SdySdSgxcSyRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : StringProtocol>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "description",
+          "printedName": "description",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd11descriptionSSvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd16debugDescriptionSSvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "exponentBitCount",
+          "printedName": "exponentBitCount",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd16exponentBitCountSivgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd16exponentBitCountSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "significandBitCount",
+          "printedName": "significandBitCount",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd19significandBitCountSivgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd19significandBitCountSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "bitPattern",
+          "printedName": "bitPattern",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt64",
+                  "printedName": "UInt64",
+                  "usr": "s:s6UInt64V"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd10bitPatterns6UInt64Vvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd10bitPatterns6UInt64Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(bitPattern:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd10bitPatternSds6UInt64V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "sign",
+          "printedName": "sign",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointSign",
+              "printedName": "FloatingPointSign",
+              "usr": "s:s17FloatingPointSignO"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "FloatingPointSign",
+                  "printedName": "FloatingPointSign",
+                  "usr": "s:s17FloatingPointSignO"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd4signs17FloatingPointSignOvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd4signs17FloatingPointSignOvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "exponentBitPattern",
+          "printedName": "exponentBitPattern",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd18exponentBitPatternSuvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd18exponentBitPatternSuvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "significandBitPattern",
+          "printedName": "significandBitPattern",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt64",
+                  "printedName": "UInt64",
+                  "usr": "s:s6UInt64V"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd21significandBitPatterns6UInt64Vvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd21significandBitPatterns6UInt64Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(sign:exponentBitPattern:significandBitPattern:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointSign",
+              "printedName": "FloatingPointSign",
+              "usr": "s:s17FloatingPointSignO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd4sign18exponentBitPattern011significandcD0Sds17FloatingPointSignO_Sus6UInt64Vtcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isCanonical",
+          "printedName": "isCanonical",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd11isCanonicalSbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd11isCanonicalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "infinity",
+          "printedName": "infinity",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd8infinitySdvgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd8infinitySdvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "nan",
+          "printedName": "nan",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd3nanSdvgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd3nanSdvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "signalingNaN",
+          "printedName": "signalingNaN",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd12signalingNaNSdvgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd12signalingNaNSdvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "greatestFiniteMagnitude",
+          "printedName": "greatestFiniteMagnitude",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd23greatestFiniteMagnitudeSdvgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd23greatestFiniteMagnitudeSdvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "pi",
+          "printedName": "pi",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd2piSdvgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd2piSdvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "ulp",
+          "printedName": "ulp",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd3ulpSdvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd3ulpSdvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "leastNormalMagnitude",
+          "printedName": "leastNormalMagnitude",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd20leastNormalMagnitudeSdvgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd20leastNormalMagnitudeSdvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "leastNonzeroMagnitude",
+          "printedName": "leastNonzeroMagnitude",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd21leastNonzeroMagnitudeSdvgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd21leastNonzeroMagnitudeSdvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "ulpOfOne",
+          "printedName": "ulpOfOne",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd8ulpOfOneSdvgZ",
+              "moduleName": "Swift",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd8ulpOfOneSdvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "exponent",
+          "printedName": "exponent",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd8exponentSivg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd8exponentSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "significand",
+          "printedName": "significand",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd11significandSdvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd11significandSdvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(sign:exponent:significand:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointSign",
+              "printedName": "FloatingPointSign",
+              "usr": "s:s17FloatingPointSignO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd4sign8exponent11significandSds17FloatingPointSignO_SiSdtcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(nan:signaling:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd3nan9signalingSds6UInt64V_Sbtcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "nextUp",
+          "printedName": "nextUp",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd6nextUpSdvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd6nextUpSdvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "round",
+          "printedName": "round(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointRoundingRule",
+              "printedName": "FloatingPointRoundingRule",
+              "usr": "s:s25FloatingPointRoundingRuleO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd5roundyys25FloatingPointRoundingRuleOF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "negate",
+          "printedName": "negate()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd6negateyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd2peoiyySdz_SdtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd2seoiyySdz_SdtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd2meoiyySdz_SdtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd2deoiyySdz_SdtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formRemainder",
+          "printedName": "formRemainder(dividingBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd13formRemainder10dividingByySd_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "formTruncatingRemainder",
+          "printedName": "formTruncatingRemainder(dividingBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd23formTruncatingRemainder10dividingByySd_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "formSquareRoot",
+          "printedName": "formSquareRoot()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd14formSquareRootyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "addProduct",
+          "printedName": "addProduct(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd10addProductyySd_SdtF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "isEqual",
+          "printedName": "isEqual(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd7isEqual2toSbSd_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isLess",
+          "printedName": "isLess(than:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd6isLess4thanSbSd_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isLessThanOrEqualTo",
+          "printedName": "isLessThanOrEqualTo(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd19isLessThanOrEqualToySbSdF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isNormal",
+          "printedName": "isNormal",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd8isNormalSbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd8isNormalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isFinite",
+          "printedName": "isFinite",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd8isFiniteSbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd8isFiniteSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isZero",
+          "printedName": "isZero",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd6isZeroSbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd6isZeroSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isSubnormal",
+          "printedName": "isSubnormal",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd11isSubnormalSbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd11isSubnormalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isInfinite",
+          "printedName": "isInfinite",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd10isInfiniteSbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd10isInfiniteSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isNaN",
+          "printedName": "isNaN",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd5isNaNSbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd5isNaNSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isSignalingNaN",
+          "printedName": "isSignalingNaN",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd14isSignalingNaNSbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd14isSignalingNaNSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "binade",
+          "printedName": "binade",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd6binadeSdvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd6binadeSdvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "significandWidth",
+          "printedName": "significandWidth",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd16significandWidthSivg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd16significandWidthSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(floatLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd12floatLiteralS2d_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(integerLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd14integerLiteralSds5Int64V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "hash",
+          "printedName": "hash(into:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Hasher",
+              "printedName": "Hasher",
+              "usr": "s:s6HasherV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "hashValue",
+          "printedName": "hashValue",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Var",
+          "name": "magnitude",
+          "printedName": "magnitude",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd9magnitudeSdvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd9magnitudeSdvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd1sopyS2dFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SdySdSicfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SdySdxcSzRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SdySdSfcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Double>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd7exactlySdSgSf_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SdyS2dcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Double>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd7exactlySdSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SdySds7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Double>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd7exactlySdSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd1poiyS2d_SdtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd1soiyS2d_SdtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd1moiyS2d_SdtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd1doiyS2d_SdtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd8distance2toS2d_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "advanced",
+          "printedName": "advanced(by:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd8advanced2byS2d_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "customMirror",
+          "printedName": "customMirror",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Mirror",
+              "printedName": "Mirror",
+              "usr": "s:s6MirrorV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd12customMirrors0B0Vvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd12customMirrors0B0Vvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "customPlaygroundQuickLook",
+          "printedName": "customPlaygroundQuickLook",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "_PlaygroundQuickLook",
+              "printedName": "_PlaygroundQuickLook",
+              "usr": "s:s20_PlaygroundQuickLookO"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_PlaygroundQuickLook",
+                  "printedName": "_PlaygroundQuickLook",
+                  "usr": "s:s20_PlaygroundQuickLookO"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
+          ]
+        }
+      ],
       "declKind": "Struct",
       "usr": "s:Sd",
-      "location": "",
       "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
-        "Decodable",
         "Encodable",
+        "Decodable",
         "LosslessStringConvertible",
         "CustomStringConvertible",
         "CustomDebugStringConvertible",
@@ -40032,129 +41788,130 @@
         "_CVarArgPassedAsDouble",
         "_CVarArgAligned",
         "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Float80",
+      "printedName": "Float80",
       "children": [
         {
+          "kind": "Var",
+          "name": "_value",
+          "printedName": "_value",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "BuiltinFloat",
+              "printedName": "Builtin.FPIEEE80"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinFloat",
+                  "printedName": "Builtin.FPIEEE80"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V6_valueBf80_vg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinFloat",
+                  "printedName": "Builtin.FPIEEE80"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V6_valueBf80_vs",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V6_valueBf80_vp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
           "declKind": "Constructor",
-          "usr": "s:S2dycfc",
-          "location": "",
+          "usr": "s:s7Float80VABycfc",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd4fromSds7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:Sd6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySdSgxcSyRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : StringProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Float80>",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "S"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80VyABSgxcSyRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : StringProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:Sd11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40166,10 +41923,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40177,18 +41930,23 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V11descriptionSSvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Sd16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -40200,10 +41958,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40211,73 +41965,20 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V16debugDescriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Magnitude",
-          "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:Sd9Magnitudea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Exponent",
-          "printedName": "Exponent",
-          "declKind": "TypeAlias",
-          "usr": "s:Sd8Exponenta",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "RawSignificand",
-          "printedName": "RawSignificand",
-          "declKind": "TypeAlias",
-          "usr": "s:Sd14RawSignificanda",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "exponentBitCount",
           "printedName": "exponentBitCount",
-          "declKind": "Var",
-          "usr": "s:Sd16exponentBitCountSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40289,11 +41990,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd16exponentBitCountSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40301,22 +41997,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V16exponentBitCountSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V16exponentBitCountSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "significandBitCount",
           "printedName": "significandBitCount",
-          "declKind": "Var",
-          "usr": "s:Sd19significandBitCountSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40328,11 +42027,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd19significandBitCountSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40340,84 +42034,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "bitPattern",
-          "printedName": "bitPattern",
-          "declKind": "Var",
-          "usr": "s:Sd10bitPatterns6UInt64Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
+              ],
               "declKind": "Accessor",
-              "usr": "s:Sd10bitPatterns6UInt64Vvg",
-              "location": "",
+              "usr": "s:s7Float80V19significandBitCountSivgZ",
               "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt64",
-                  "printedName": "UInt64",
-                  "usr": "s:s6UInt64V"
-                }
-              ]
+              "static": true
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd10bitPatternSds6UInt64V_tcfc",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V19significandBitCountSivpZ",
           "moduleName": "Swift",
+          "static": true,
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
           ]
         },
         {
           "kind": "Var",
           "name": "sign",
           "printedName": "sign",
-          "declKind": "Var",
-          "usr": "s:Sd4signs17FloatingPointSignOvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40429,10 +42064,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd4signs17FloatingPointSignOvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40440,21 +42071,23 @@
                   "printedName": "FloatingPointSign",
                   "usr": "s:s17FloatingPointSignO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V4signs17FloatingPointSignOvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V4signs17FloatingPointSignOvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "exponentBitPattern",
           "printedName": "exponentBitPattern",
-          "declKind": "Var",
-          "usr": "s:Sd18exponentBitPatternSuvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40466,10 +42099,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd18exponentBitPatternSuvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40477,21 +42106,23 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V18exponentBitPatternSuvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V18exponentBitPatternSuvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "significandBitPattern",
           "printedName": "significandBitPattern",
-          "declKind": "Var",
-          "usr": "s:Sd21significandBitPatterns6UInt64Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40503,10 +42134,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd21significandBitPatterns6UInt64Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40514,27 +42141,29 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V21significandBitPatterns6UInt64Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V21significandBitPatterns6UInt64Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(sign:exponentBitPattern:significandBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd4sign18exponentBitPattern011significandcD0Sds17FloatingPointSignO_Sus6UInt64Vtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "TypeNominal",
@@ -40554,19 +42183,18 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80V4sign18exponentBitPattern011significanddE0ABs17FloatingPointSignO_Sus6UInt64Vtcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "isCanonical",
           "printedName": "isCanonical",
-          "declKind": "Var",
-          "usr": "s:Sd11isCanonicalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40578,10 +42206,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd11isCanonicalSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40589,370 +42213,354 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V11isCanonicalSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V11isCanonicalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "infinity",
           "printedName": "infinity",
-          "declKind": "Var",
-          "usr": "s:Sd8infinitySdvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd8infinitySdvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V8infinityABvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V8infinityABvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "nan",
           "printedName": "nan",
-          "declKind": "Var",
-          "usr": "s:Sd3nanSdvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd3nanSdvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V3nanABvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V3nanABvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "signalingNaN",
           "printedName": "signalingNaN",
-          "declKind": "Var",
-          "usr": "s:Sd12signalingNaNSdvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd12signalingNaNSdvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V12signalingNaNABvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V12signalingNaNABvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "greatestFiniteMagnitude",
           "printedName": "greatestFiniteMagnitude",
-          "declKind": "Var",
-          "usr": "s:Sd23greatestFiniteMagnitudeSdvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd23greatestFiniteMagnitudeSdvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V23greatestFiniteMagnitudeABvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V23greatestFiniteMagnitudeABvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "pi",
           "printedName": "pi",
-          "declKind": "Var",
-          "usr": "s:Sd2piSdvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd2piSdvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V2piABvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V2piABvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "ulp",
           "printedName": "ulp",
-          "declKind": "Var",
-          "usr": "s:Sd3ulpSdvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd3ulpSdvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V3ulpABvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V3ulpABvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "leastNormalMagnitude",
           "printedName": "leastNormalMagnitude",
-          "declKind": "Var",
-          "usr": "s:Sd20leastNormalMagnitudeSdvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd20leastNormalMagnitudeSdvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V20leastNormalMagnitudeABvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V20leastNormalMagnitudeABvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "leastNonzeroMagnitude",
           "printedName": "leastNonzeroMagnitude",
-          "declKind": "Var",
-          "usr": "s:Sd21leastNonzeroMagnitudeSdvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd21leastNonzeroMagnitudeSdvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V21leastNonzeroMagnitudeABvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V21leastNonzeroMagnitudeABvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "ulpOfOne",
           "printedName": "ulpOfOne",
-          "declKind": "Var",
-          "usr": "s:Sd8ulpOfOneSdvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd8ulpOfOneSdvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V8ulpOfOneABvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V8ulpOfOneABvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "exponent",
           "printedName": "exponent",
-          "declKind": "Var",
-          "usr": "s:Sd8exponentSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40964,10 +42572,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd8exponentSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40975,64 +42579,64 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V8exponentSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V8exponentSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "significand",
           "printedName": "significand",
-          "declKind": "Var",
-          "usr": "s:Sd11significandSdvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd11significandSdvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V11significandABvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V11significandABvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(sign:exponent:significand:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd4sign8exponent11significandSds17FloatingPointSignO_SiSdtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "TypeNominal",
@@ -41048,42 +42652,34 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80V4sign8exponent11significandABs17FloatingPointSignO_SiABtcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(nan:signaling:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd3nan9signalingSds6UInt64V_Sbtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "RawSignificand",
-              "printedName": "Double.RawSignificand",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt64",
-                  "printedName": "UInt64",
-                  "usr": "s:s6UInt64V"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
             },
             {
               "kind": "TypeNominal",
@@ -41091,57 +42687,53 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80V3nan9signalingABs6UInt64V_Sbtcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "nextUp",
           "printedName": "nextUp",
-          "declKind": "Var",
-          "usr": "s:Sd6nextUpSdvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd6nextUpSdvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V6nextUpABvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V6nextUpABvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "round",
           "printedName": "round(_:)",
-          "declKind": "Func",
-          "usr": "s:Sd5roundyys25FloatingPointRoundingRuleOF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41154,40 +42746,162 @@
               "printedName": "FloatingPointRoundingRule",
               "usr": "s:s25FloatingPointRoundingRuleO"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V5roundyys25FloatingPointRoundingRuleOF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "negate",
           "printedName": "negate()",
-          "declKind": "Func",
-          "usr": "s:Sd6negateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V6negateyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "formRemainder",
           "printedName": "formRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:Sd13formRemainder10dividingByySd_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41196,24 +42910,23 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V13formRemainder10dividingByyAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "formTruncatingRemainder",
           "printedName": "formTruncatingRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:Sd23formTruncatingRemainder10dividingByySd_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41222,44 +42935,42 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V23formTruncatingRemainder10dividingByyAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "formSquareRoot",
           "printedName": "formSquareRoot()",
-          "declKind": "Func",
-          "usr": "s:Sd14formSquareRootyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V14formSquareRootyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "addProduct",
           "printedName": "addProduct(_:_:)",
-          "declKind": "Func",
-          "usr": "s:Sd10addProductyySd_SdtF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41268,29 +42979,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V10addProductyyAB_ABtF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "isEqual",
           "printedName": "isEqual(to:)",
-          "declKind": "Func",
-          "usr": "s:Sd7isEqual2toSbSd_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41300,23 +43011,22 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V7isEqual2toSbAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "isLess",
           "printedName": "isLess(than:)",
-          "declKind": "Func",
-          "usr": "s:Sd6isLess4thanSbSd_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41326,23 +43036,22 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V6isLess4thanSbAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "isLessThanOrEqualTo",
           "printedName": "isLessThanOrEqualTo(_:)",
-          "declKind": "Func",
-          "usr": "s:Sd19isLessThanOrEqualToySbSdF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41352,23 +43061,22 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V19isLessThanOrEqualToySbABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isNormal",
           "printedName": "isNormal",
-          "declKind": "Var",
-          "usr": "s:Sd8isNormalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41380,10 +43088,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd8isNormalSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41391,21 +43095,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V8isNormalSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V8isNormalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isFinite",
           "printedName": "isFinite",
-          "declKind": "Var",
-          "usr": "s:Sd8isFiniteSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41417,10 +43123,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd8isFiniteSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41428,21 +43130,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V8isFiniteSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V8isFiniteSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isZero",
           "printedName": "isZero",
-          "declKind": "Var",
-          "usr": "s:Sd6isZeroSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41454,10 +43158,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd6isZeroSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41465,21 +43165,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V6isZeroSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V6isZeroSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isSubnormal",
           "printedName": "isSubnormal",
-          "declKind": "Var",
-          "usr": "s:Sd11isSubnormalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41491,10 +43193,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd11isSubnormalSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41502,21 +43200,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V11isSubnormalSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V11isSubnormalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isInfinite",
           "printedName": "isInfinite",
-          "declKind": "Var",
-          "usr": "s:Sd10isInfiniteSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41528,10 +43228,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd10isInfiniteSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41539,21 +43235,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V10isInfiniteSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V10isInfiniteSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isNaN",
           "printedName": "isNaN",
-          "declKind": "Var",
-          "usr": "s:Sd5isNaNSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41565,10 +43263,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd5isNaNSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41576,21 +43270,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V5isNaNSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V5isNaNSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isSignalingNaN",
           "printedName": "isSignalingNaN",
-          "declKind": "Var",
-          "usr": "s:Sd14isSignalingNaNSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41602,10 +43298,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd14isSignalingNaNSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41613,58 +43305,58 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V14isSignalingNaNSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V14isSignalingNaNSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "binade",
           "printedName": "binade",
-          "declKind": "Var",
-          "usr": "s:Sd6binadeSdvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd6binadeSdvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V6binadeABvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V6binadeABvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "significandWidth",
           "printedName": "significandWidth",
-          "declKind": "Var",
-          "usr": "s:Sd16significandWidthSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41676,10 +43368,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd16significandWidthSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41687,87 +43375,54 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V16significandWidthSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V16significandWidthSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(floatLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd12floatLiteralS2d_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "FloatLiteralType",
-          "printedName": "FloatLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Sd16FloatLiteralTypea",
-          "location": "",
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80V12floatLiteralA2B_tcfc",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "RawExponent",
-          "printedName": "RawExponent",
-          "declKind": "TypeAlias",
-          "usr": "s:Sd11RawExponenta",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(integerLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd14integerLiteralSds5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "TypeNominal",
@@ -41775,36 +43430,18 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "IntegerLiteralType",
-          "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Sd18IntegerLiteralTypea",
-          "location": "",
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80V14integerLiteralABs5Int64V_tcfc",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:Sd4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41817,16 +43454,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Sd9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -41838,10 +43477,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41849,802 +43484,63 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:Sd9magnitudeSdvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
+                }
+              ],
               "declKind": "Accessor",
-              "usr": "s:Sd9magnitudeSdvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
+              "usr": "s:s7Float80V9magnitudeABvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds5UInt8Vcfc",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V9magnitudeABvp",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            }
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs5UInt8V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds4Int8Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs4Int8V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds6UInt16Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs6UInt16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds5Int16Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs5Int16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds6UInt32Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds5Int32Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs5Int32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds6UInt64Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds5Int64Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySdSucfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySdSicfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySdSfcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgSf_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdyS2dcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "TypeNominal",
@@ -42652,34 +43548,194 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V1sopyA2BFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80VyABSicfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80VyABxcSzRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80VyABSfcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Float80>",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80V7exactlyABSgSf_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80VyABSdcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Float80>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "TypeNominal",
@@ -42687,85 +43743,230 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80VyA2Bcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Float80>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80V7exactlyABSgAB_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(to:)",
-          "declKind": "Func",
-          "usr": "s:Sd8distance2toS2d_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V8distance2toA2B_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "advanced",
           "printedName": "advanced(by:)",
-          "declKind": "Func",
-          "usr": "s:Sd8advanced2byS2d_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             },
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:Sd6Stridea",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V8advanced2byA2B_tF",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Sd12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -42777,10 +43978,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -42788,59 +43985,23 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customPlaygroundQuickLook",
-          "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:Sd25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "_PlaygroundQuickLook",
-              "printedName": "_PlaygroundQuickLook",
-              "usr": "s:s20_PlaygroundQuickLookO"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
+              ],
               "declKind": "Accessor",
-              "usr": "s:Sd25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "_PlaygroundQuickLook",
-                  "printedName": "_PlaygroundQuickLook",
-                  "usr": "s:s20_PlaygroundQuickLookO"
-                }
-              ]
+              "usr": "s:s7Float80V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "Float80",
-      "printedName": "Float80",
+      ],
       "declKind": "Struct",
       "usr": "s:s7Float80V",
-      "location": "",
       "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "LosslessStringConvertible",
         "CustomStringConvertible",
@@ -42859,2677 +44020,17 @@
         "Strideable",
         "Comparable",
         "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VABycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABSgxcSyRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : StringProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "description",
-          "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:s7Float80V11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "debugDescription",
-          "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s7Float80V16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Magnitude",
-          "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s7Float80V9Magnitudea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Exponent",
-          "printedName": "Exponent",
-          "declKind": "TypeAlias",
-          "usr": "s:s7Float80V8Exponenta",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "RawSignificand",
-          "printedName": "RawSignificand",
-          "declKind": "TypeAlias",
-          "usr": "s:s7Float80V14RawSignificanda",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "exponentBitCount",
-          "printedName": "exponentBitCount",
-          "declKind": "Var",
-          "usr": "s:s7Float80V16exponentBitCountSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V16exponentBitCountSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "significandBitCount",
-          "printedName": "significandBitCount",
-          "declKind": "Var",
-          "usr": "s:s7Float80V19significandBitCountSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V19significandBitCountSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "sign",
-          "printedName": "sign",
-          "declKind": "Var",
-          "usr": "s:s7Float80V4signs17FloatingPointSignOvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "FloatingPointSign",
-              "printedName": "FloatingPointSign",
-              "usr": "s:s17FloatingPointSignO"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V4signs17FloatingPointSignOvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "FloatingPointSign",
-                  "printedName": "FloatingPointSign",
-                  "usr": "s:s17FloatingPointSignO"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "exponentBitPattern",
-          "printedName": "exponentBitPattern",
-          "declKind": "Var",
-          "usr": "s:s7Float80V18exponentBitPatternSuvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V18exponentBitPatternSuvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt",
-                  "printedName": "UInt",
-                  "usr": "s:Su"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "significandBitPattern",
-          "printedName": "significandBitPattern",
-          "declKind": "Var",
-          "usr": "s:s7Float80V21significandBitPatterns6UInt64Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V21significandBitPatterns6UInt64Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt64",
-                  "printedName": "UInt64",
-                  "usr": "s:s6UInt64V"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(sign:exponentBitPattern:significandBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V4sign18exponentBitPattern011significanddE0ABs17FloatingPointSignO_Sus6UInt64Vtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "FloatingPointSign",
-              "printedName": "FloatingPointSign",
-              "usr": "s:s17FloatingPointSignO"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isCanonical",
-          "printedName": "isCanonical",
-          "declKind": "Var",
-          "usr": "s:s7Float80V11isCanonicalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V11isCanonicalSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "infinity",
-          "printedName": "infinity",
-          "declKind": "Var",
-          "usr": "s:s7Float80V8infinityABvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V8infinityABvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "nan",
-          "printedName": "nan",
-          "declKind": "Var",
-          "usr": "s:s7Float80V3nanABvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V3nanABvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "signalingNaN",
-          "printedName": "signalingNaN",
-          "declKind": "Var",
-          "usr": "s:s7Float80V12signalingNaNABvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V12signalingNaNABvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "greatestFiniteMagnitude",
-          "printedName": "greatestFiniteMagnitude",
-          "declKind": "Var",
-          "usr": "s:s7Float80V23greatestFiniteMagnitudeABvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V23greatestFiniteMagnitudeABvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "pi",
-          "printedName": "pi",
-          "declKind": "Var",
-          "usr": "s:s7Float80V2piABvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V2piABvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "ulp",
-          "printedName": "ulp",
-          "declKind": "Var",
-          "usr": "s:s7Float80V3ulpABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V3ulpABvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "leastNormalMagnitude",
-          "printedName": "leastNormalMagnitude",
-          "declKind": "Var",
-          "usr": "s:s7Float80V20leastNormalMagnitudeABvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V20leastNormalMagnitudeABvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "leastNonzeroMagnitude",
-          "printedName": "leastNonzeroMagnitude",
-          "declKind": "Var",
-          "usr": "s:s7Float80V21leastNonzeroMagnitudeABvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V21leastNonzeroMagnitudeABvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "ulpOfOne",
-          "printedName": "ulpOfOne",
-          "declKind": "Var",
-          "usr": "s:s7Float80V8ulpOfOneABvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V8ulpOfOneABvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "exponent",
-          "printedName": "exponent",
-          "declKind": "Var",
-          "usr": "s:s7Float80V8exponentSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V8exponentSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "significand",
-          "printedName": "significand",
-          "declKind": "Var",
-          "usr": "s:s7Float80V11significandABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V11significandABvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(sign:exponent:significand:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V4sign8exponent11significandABs17FloatingPointSignO_SiABtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "FloatingPointSign",
-              "printedName": "FloatingPointSign",
-              "usr": "s:s17FloatingPointSignO"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(nan:signaling:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V3nan9signalingABs6UInt64V_Sbtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "RawSignificand",
-              "printedName": "Float80.RawSignificand",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt64",
-                  "printedName": "UInt64",
-                  "usr": "s:s6UInt64V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "nextUp",
-          "printedName": "nextUp",
-          "declKind": "Var",
-          "usr": "s:s7Float80V6nextUpABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V6nextUpABvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "round",
-          "printedName": "round(_:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V5roundyys25FloatingPointRoundingRuleOF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "FloatingPointRoundingRule",
-              "printedName": "FloatingPointRoundingRule",
-              "usr": "s:s25FloatingPointRoundingRuleO"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "negate",
-          "printedName": "negate()",
-          "declKind": "Func",
-          "usr": "s:s7Float80V6negateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formRemainder",
-          "printedName": "formRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V13formRemainder10dividingByyAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formTruncatingRemainder",
-          "printedName": "formTruncatingRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V23formTruncatingRemainder10dividingByyAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formSquareRoot",
-          "printedName": "formSquareRoot()",
-          "declKind": "Func",
-          "usr": "s:s7Float80V14formSquareRootyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "addProduct",
-          "printedName": "addProduct(_:_:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V10addProductyyAB_ABtF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isEqual",
-          "printedName": "isEqual(to:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V7isEqual2toSbAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isLess",
-          "printedName": "isLess(than:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V6isLess4thanSbAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isLessThanOrEqualTo",
-          "printedName": "isLessThanOrEqualTo(_:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V19isLessThanOrEqualToySbABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isNormal",
-          "printedName": "isNormal",
-          "declKind": "Var",
-          "usr": "s:s7Float80V8isNormalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V8isNormalSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isFinite",
-          "printedName": "isFinite",
-          "declKind": "Var",
-          "usr": "s:s7Float80V8isFiniteSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V8isFiniteSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isZero",
-          "printedName": "isZero",
-          "declKind": "Var",
-          "usr": "s:s7Float80V6isZeroSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V6isZeroSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isSubnormal",
-          "printedName": "isSubnormal",
-          "declKind": "Var",
-          "usr": "s:s7Float80V11isSubnormalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V11isSubnormalSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isInfinite",
-          "printedName": "isInfinite",
-          "declKind": "Var",
-          "usr": "s:s7Float80V10isInfiniteSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V10isInfiniteSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isNaN",
-          "printedName": "isNaN",
-          "declKind": "Var",
-          "usr": "s:s7Float80V5isNaNSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V5isNaNSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isSignalingNaN",
-          "printedName": "isSignalingNaN",
-          "declKind": "Var",
-          "usr": "s:s7Float80V14isSignalingNaNSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V14isSignalingNaNSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "binade",
-          "printedName": "binade",
-          "declKind": "Var",
-          "usr": "s:s7Float80V6binadeABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V6binadeABvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "significandWidth",
-          "printedName": "significandWidth",
-          "declKind": "Var",
-          "usr": "s:s7Float80V16significandWidthSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V16significandWidthSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(floatLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V12floatLiteralA2B_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "FloatLiteralType",
-          "printedName": "FloatLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s7Float80V16FloatLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "RawExponent",
-          "printedName": "RawExponent",
-          "declKind": "TypeAlias",
-          "usr": "s:s7Float80V11RawExponenta",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(integerLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V14integerLiteralABs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "IntegerLiteralType",
-          "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s7Float80V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "hash",
-          "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Hasher",
-              "printedName": "Hasher",
-              "usr": "s:s6HasherV"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "hashValue",
-          "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s7Float80V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "magnitude",
-          "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:s7Float80V9magnitudeABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V9magnitudeABvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABs5UInt8Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgs5UInt8V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABs4Int8Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgs4Int8V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABs6UInt16Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgs6UInt16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABs5Int16Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgs5Int16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABs6UInt32Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABs5Int32Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgs5Int32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABs6UInt64Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABs5Int64Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABSucfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABSicfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABSfcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgSf_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABSdcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyA2Bcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgAB_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(to:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V8distance2toA2B_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "advanced",
-          "printedName": "advanced(by:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V8advanced2byA2B_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s7Float80V6Stridea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s7Float80V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                }
-              ]
-            }
-          ]
-        }
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Hashable",
       "printedName": "Hashable",
-      "declKind": "Protocol",
-      "usr": "s:SH",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Equatable>",
-      "conformingProtocols": [
-        "Equatable"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SH9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -45541,11 +44042,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SH9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -45553,19 +44049,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SH9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SH9hashValueSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SH4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Hashable>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -45578,41 +44077,74 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SH4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "protocolReq": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SH",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : Equatable>",
+      "conformingProtocols": [
+        "Equatable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AnyHashable",
       "printedName": "AnyHashable",
-      "declKind": "Struct",
-      "usr": "s:s11AnyHashableV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable",
-        "CustomStringConvertible",
-        "CustomDebugStringConvertible",
-        "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
+          "kind": "Var",
+          "name": "_box",
+          "printedName": "_box",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "_AnyHashableBox",
+              "printedName": "_AnyHashableBox",
+              "usr": "s:s15_AnyHashableBoxP"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_AnyHashableBox",
+                  "printedName": "_AnyHashableBox",
+                  "usr": "s:s15_AnyHashableBoxP"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11AnyHashableV4_boxs01_aB3Box_pvg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s11AnyHashableV4_boxs01_aB3Box_pvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s11AnyHashableVyABxcSHRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<H where H : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45623,21 +44155,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "H"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s11AnyHashableVyABxcSHRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "base",
           "printedName": "base",
-          "declKind": "Var",
-          "usr": "s:s11AnyHashableV4baseypvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45648,31 +44180,61 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11AnyHashableV4baseypvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ProtocolComposition",
                   "printedName": "Any"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11AnyHashableV4baseypvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s11AnyHashableV4baseypvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyHashable",
+              "printedName": "AnyHashable",
+              "usr": "s:s11AnyHashableV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyHashable",
+              "printedName": "AnyHashable",
+              "usr": "s:s11AnyHashableV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnyHashableV2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s11AnyHashableV9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45684,10 +44246,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11AnyHashableV9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -45695,21 +44253,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11AnyHashableV9hashValueSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s11AnyHashableV9hashValueSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s11AnyHashableV4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45722,19 +44282,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnyHashableV4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:s11AnyHashableV11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45746,10 +44305,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11AnyHashableV11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -45757,18 +44312,23 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11AnyHashableV11descriptionSSvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s11AnyHashableV11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s11AnyHashableV16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -45780,10 +44340,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11AnyHashableV16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -45791,21 +44347,20 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11AnyHashableV16debugDescriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s11AnyHashableV16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s11AnyHashableV12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45817,10 +44372,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11AnyHashableV12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -45828,35 +44379,99 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11AnyHashableV12customMirrors0D0Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s11AnyHashableV12customMirrors0D0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s11AnyHashableV",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable",
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible",
+        "CustomReflectable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Hasher",
       "printedName": "Hasher",
-      "declKind": "Struct",
-      "usr": "s:s6HasherV",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
+          "kind": "Var",
+          "name": "_core",
+          "printedName": "_core",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "_BufferingHasher",
+              "printedName": "_BufferingHasher<_SipHash13Core>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_SipHash13Core",
+                  "printedName": "_SipHash13Core",
+                  "usr": "s:s14_SipHash13CoreV"
+                }
+              ],
+              "usr": "s:s16_BufferingHasherV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_BufferingHasher",
+                  "printedName": "_BufferingHasher<_SipHash13Core>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_SipHash13Core",
+                      "printedName": "_SipHash13Core",
+                      "usr": "s:s14_SipHash13CoreV"
+                    }
+                  ],
+                  "usr": "s:s16_BufferingHasherV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6HasherV5_cores010_BufferingA0Vys14_SipHash13CoreVGvg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6HasherV5_cores010_BufferingA0Vys14_SipHash13CoreVGvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s6HasherVABycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Effects"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45864,22 +44479,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6HasherVABycfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Effects"
           ]
         },
         {
           "kind": "Function",
           "name": "combine",
           "printedName": "combine(_:)",
-          "declKind": "Func",
-          "usr": "s:s6HasherV7combineyyxSHRzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<H where H : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45889,22 +44500,23 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "H"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s6HasherV7combineyyxSHRzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "combine",
           "printedName": "combine(bytes:)",
-          "declKind": "Func",
-          "usr": "s:s6HasherV7combine5bytesySW_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Effects"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45917,19 +44529,19 @@
               "printedName": "UnsafeRawBufferPointer",
               "usr": "s:SW"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s6HasherV7combine5bytesySW_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Effects"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "finalize",
           "printedName": "finalize()",
-          "declKind": "Func",
-          "usr": "s:s6HasherV8finalizeSiyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Effects"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45937,269 +44549,313 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6HasherV8finalizeSiyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Effects"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s6HasherV",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "DefaultIndices",
       "printedName": "DefaultIndices",
-      "declKind": "Struct",
-      "usr": "s:SI",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Elements where Elements : Collection>",
-      "conformingProtocols": [
-        "Collection",
-        "Sequence",
-        "BidirectionalCollection",
-        "RandomAccessCollection"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:SI5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Elements.Index"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:SI7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Elements.Index"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:SI7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DefaultIndices",
-              "printedName": "DefaultIndices<Elements>",
-              "usr": "s:SI",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Elements"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:SI11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DefaultIndices",
-              "printedName": "DefaultIndices<Elements>",
-              "usr": "s:SI",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Elements"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:SI8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "IndexingIterator",
-              "printedName": "IndexingIterator<DefaultIndices<Elements>>",
-              "usr": "s:s16IndexingIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DefaultIndices",
-                  "printedName": "DefaultIndices<Elements>",
-                  "usr": "s:SI",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Elements"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
           "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:SI10startIndex0B0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "name": "_elements",
+          "printedName": "_elements",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Elements.Index"
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
               "declKind": "Accessor",
-              "usr": "s:SI10startIndex0B0Qzvg",
-              "location": "",
+              "usr": "s:SI9_elementsxvg",
               "moduleName": "Swift",
-              "genericSig": "<Elements where Elements : Collection>",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SI9_elementsxvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_startIndex",
+          "printedName": "_startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Elements.Index"
+                  "printedName": "τ_0_0.Index"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SI11_startIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SI11_startIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_endIndex",
+          "printedName": "_endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SI9_endIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SI9_endIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 2,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SI10startIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SI10startIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:SI8endIndex0B0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Elements.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SI8endIndex0B0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Elements where Elements : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Elements.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SI8endIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SI8endIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SIy5IndexQzABcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DefaultIndices",
+              "printedName": "DefaultIndices<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SI"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SIySIyxGSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:SI5index5after5IndexQzAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "DefaultIndices<Elements>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "DefaultIndices<Elements>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SI5index5after5IndexQzAD_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:SI9formIndex5aftery0B0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -46207,122 +44863,97 @@
               "printedName": "()"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "DefaultIndices<Elements>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SI9formIndex5aftery0B0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:SI7indicesSIyxGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DefaultIndices",
-              "printedName": "DefaultIndices<Elements>",
-              "usr": "s:SI",
+              "printedName": "DefaultIndices<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Elements"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:SI"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SI7indicesSIyxGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Elements where Elements : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DefaultIndices",
-                  "printedName": "DefaultIndices<Elements>",
-                  "usr": "s:SI",
+                  "printedName": "DefaultIndices<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Elements"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:SI"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SI7indicesSIyxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SI7indicesSIyxGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:SIsSKRzrlE5index6before5IndexQzAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "DefaultIndices<Elements>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "DefaultIndices<Elements>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SIsSKRzrlE5index6before5IndexQzAD_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:SIsSKRzrlE9formIndex6beforey0B0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -46330,35 +44961,43 @@
               "printedName": "()"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "DefaultIndices<Elements>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SIsSKRzrlE9formIndex6beforey0B0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:SI",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Collection",
+        "Sequence",
+        "BidirectionalCollection",
+        "RandomAccessCollection"
       ]
     },
     {
       "kind": "Function",
       "name": "readLine",
       "printedName": "readLine(strippingNewline:)",
-      "declKind": "Func",
-      "usr": "s:s8readLine16strippingNewlineSSSgSb_tF",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Optional",
-          "printedName": "String?",
-          "usr": "s:Sq",
+          "printedName": "Optional<String>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -46366,7 +45005,8 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "usr": "s:Sq"
         },
         {
           "kind": "TypeNominal",
@@ -46375,288 +45015,454 @@
           "hasDefaultArg": true,
           "usr": "s:Sb"
         }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "IntMax",
-      "printedName": "IntMax",
-      "declKind": "TypeAlias",
-      "usr": "s:s6IntMaxa",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Available"
       ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Int64",
-          "printedName": "Int64",
-          "usr": "s:s5Int64V"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "UIntMax",
-      "printedName": "UIntMax",
-      "declKind": "TypeAlias",
-      "usr": "s:s7UIntMaxa",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "UInt64",
-          "printedName": "UInt64",
-          "usr": "s:s6UInt64V"
-        }
-      ]
+      "declKind": "Func",
+      "usr": "s:s8readLine16strippingNewlineSSSgSb_tF",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "Numeric",
       "printedName": "Numeric",
-      "declKind": "Protocol",
-      "usr": "s:Sj",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Equatable, Self : ExpressibleByIntegerLiteral, Self.Magnitude : Comparable, Self.Magnitude : Numeric>",
-      "conformingProtocols": [
-        "Equatable",
-        "ExpressibleByIntegerLiteral"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sj7exactlyxSgqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Numeric, T : BinaryInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sj7exactlyxSgqd___tcSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Numeric, τ_1_0 : BinaryInteger>",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Magnitude",
+          "printedName": "Magnitude",
+          "declKind": "AssociatedType",
+          "usr": "s:Sj9MagnitudeQa",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:Sj9magnitude9MagnitudeQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Magnitude"
+              "printedName": "τ_0_0.Magnitude"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sj9magnitude9MagnitudeQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Numeric>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Magnitude"
+                  "printedName": "τ_0_0.Magnitude"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sj9magnitude9MagnitudeQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Numeric>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sj9magnitude9MagnitudeQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sj1poiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Numeric>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sj2peoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Numeric>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sj1soiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Numeric>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sj2seoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Numeric>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sj1moiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Numeric>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sj2meoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Numeric>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SjsE1popyxxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Numeric>",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:Sj",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : Equatable, τ_0_0 : ExpressibleByIntegerLiteral, τ_0_0.Magnitude : Comparable, τ_0_0.Magnitude : Numeric>",
+      "conformingProtocols": [
+        "Equatable",
+        "ExpressibleByIntegerLiteral"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "SignedNumeric",
       "printedName": "SignedNumeric",
-      "declKind": "Protocol",
-      "usr": "s:s13SignedNumericP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Numeric>",
-      "conformingProtocols": [
-        "Numeric",
-        "Equatable",
-        "ExpressibleByIntegerLiteral"
-      ],
       "children": [
         {
           "kind": "Function",
-          "name": "negate",
-          "printedName": "negate()",
-          "declKind": "Func",
-          "usr": "s:s13SignedNumericP6negateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SignedNumeric>",
-          "mutating": true,
+          "name": "-",
+          "printedName": "-(_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "negate",
-          "printedName": "negate()",
-          "declKind": "Func",
-          "usr": "s:s13SignedNumericPsE6negateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SignedNumeric>",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "abs",
-          "printedName": "abs(_:)",
-          "declKind": "Func",
-          "usr": "s:s13SignedNumericPsSLRzrlE3absyxxFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Comparable, Self : SignedNumeric>",
-          "static": true,
-          "declAttributes": [
-            "Transparent",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13SignedNumericP1sopyxxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SignedNumeric>",
+          "static": true,
+          "protocolReq": true,
+          "declAttributes": [
+            "Prefix"
           ]
+        },
+        {
+          "kind": "Function",
+          "name": "negate",
+          "printedName": "negate()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13SignedNumericP6negateyyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SignedNumeric>",
+          "protocolReq": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13SignedNumericPsE1sopyxxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SignedNumeric>",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "negate",
+          "printedName": "negate()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13SignedNumericPsE6negateyyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SignedNumeric>",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s13SignedNumericP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : Numeric>",
+      "conformingProtocols": [
+        "Numeric",
+        "Equatable",
+        "ExpressibleByIntegerLiteral"
       ]
     },
     {
       "kind": "Function",
       "name": "abs",
       "printedName": "abs(_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        }
+      ],
       "declKind": "Func",
       "usr": "s:s3absyxxs13SignedNumericRz9MagnitudeSjQzRszlF",
-      "location": "",
       "moduleName": "Swift",
-      "genericSig": "<T where T : SignedNumeric, T == T.Magnitude>",
+      "genericSig": "<τ_0_0 where τ_0_0 : SignedNumeric, τ_0_0 == τ_0_0.Magnitude>",
       "declAttributes": [
-        "Transparent"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        }
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "abs",
       "printedName": "abs(_:)",
-      "declKind": "Func",
-      "usr": "s:s3absyxxSLRzs13SignedNumericRzlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Comparable, T : SignedNumeric>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s3absyxxSLRzs13SignedNumericRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Comparable, τ_0_0 : SignedNumeric>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "BinaryInteger",
       "printedName": "BinaryInteger",
-      "declKind": "Protocol",
-      "usr": "s:Sz",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : CustomStringConvertible, Self : Hashable, Self : Numeric, Self : Strideable, Self.Magnitude : BinaryInteger, Self.Magnitude == Self.Magnitude.Magnitude, Self.Words : Sequence, Self.Words.Element == UInt>",
-      "conformingProtocols": [
-        "Hashable",
-        "Numeric",
-        "CustomStringConvertible",
-        "Strideable",
-        "Equatable",
-        "ExpressibleByIntegerLiteral",
-        "Comparable"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "isSigned",
           "printedName": "isSigned",
-          "declKind": "Var",
-          "usr": "s:Sz8isSignedSbvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -46668,12 +45474,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sz8isSignedSbvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryInteger>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -46681,169 +45481,183 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sz8isSignedSbvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sz8isSignedSbvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sz7exactlyxSgqd___tcSBRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : BinaryInteger, T : BinaryFloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sz7exactlyxSgqd___tcSBRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryInteger, τ_1_0 : BinaryFloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:Szyxqd__cSBRd__lufc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : BinaryInteger, T : BinaryFloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryInteger, τ_1_0 : BinaryFloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:Szyxqd__cSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : BinaryInteger, T : BinaryInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Szyxqd__cSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryInteger, τ_1_0 : BinaryInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(truncatingIfNeeded:)",
-          "declKind": "Constructor",
-          "usr": "s:Sz18truncatingIfNeededxqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : BinaryInteger, T : BinaryInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sz18truncatingIfNeededxqd___tcSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryInteger, τ_1_0 : BinaryInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(clamping:)",
-          "declKind": "Constructor",
-          "usr": "s:Sz8clampingxqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : BinaryInteger, T : BinaryInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sz8clampingxqd___tcSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryInteger, τ_1_0 : BinaryInteger>",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Words",
+          "printedName": "Words",
+          "declKind": "AssociatedType",
+          "usr": "s:Sz5WordsQa",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:Sz5words5WordsQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Words"
+              "printedName": "τ_0_0.Words"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sz5words5WordsQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Words"
+                  "printedName": "τ_0_0.Words"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sz5words5WordsQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sz5words5WordsQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:Sz8bitWidthSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -46855,11 +45669,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sz8bitWidthSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -46867,18 +45676,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sz8bitWidthSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sz8bitWidthSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:Sz20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -46890,11 +45703,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sz20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -46902,149 +45710,957 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sz20trailingZeroBitCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sz20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1doiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2deoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1roiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2reoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1poiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2peoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1soiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2seoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1moiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2meoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "~",
+          "printedName": "~(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1topyxxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true,
+          "declAttributes": [
+            "Prefix"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1aoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2aeoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1ooiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2oeoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1xoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2xeoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": ">>",
+          "printedName": ">>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2ggoiyxx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": ">>=",
+          "printedName": ">>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz3ggeoiyyxz_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "<<",
+          "printedName": "<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2lloiyxx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "<<=",
+          "printedName": "<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz3lleoiyyxz_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
           "name": "quotientAndRemainder",
           "printedName": "quotientAndRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:Sz20quotientAndRemainder10dividingByx0A0_x9remaindertx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(quotient: Self, remainder: Self)",
+              "printedName": "(quotient: τ_0_0, remainder: τ_0_0)",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
               ]
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz20quotientAndRemainder10dividingByx0A0_x9remaindertx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "isMultiple",
+          "printedName": "isMultiple(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz10isMultiple2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:Sz6signumxyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DynamicSelf",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz6signumxyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:SzsExycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryInteger>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SzsExycfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:SzsE6signumxyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryInteger>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE6signumxyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "quotientAndRemainder",
           "printedName": "quotientAndRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:SzsE20quotientAndRemainder10dividingByx0A0_x9remaindertx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(quotient: Self, remainder: Self)",
+              "printedName": "(quotient: τ_0_0, remainder: τ_0_0)",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
               ]
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE20quotientAndRemainder10dividingByx0A0_x9remaindertx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isMultiple",
+          "printedName": "isMultiple(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE10isMultiple2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE1aoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE1ooiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE1xoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">>",
+          "printedName": ">>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2ggoiyxx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<<",
+          "printedName": "<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2lloiyxx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
           ]
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:SzsE11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -47056,11 +46672,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SzsE11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -47068,23 +46679,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SzsE11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SzsE11descriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(to:)",
-          "declKind": "Func",
-          "usr": "s:SzsE8distance2toSix_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryInteger>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -47095,28 +46704,27 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE8distance2toSix_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "advanced",
           "printedName": "advanced(by:)",
-          "declKind": "Func",
-          "usr": "s:SzsE8advanced2byxSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryInteger>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -47124,40 +46732,2023 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE8advanced2byxSi_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
-          "name": "toIntMax",
-          "printedName": "toIntMax()",
-          "declKind": "Func",
-          "usr": "s:SzsE8toIntMaxs5Int64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryInteger>",
-          "declAttributes": [
-            "Available"
-          ],
+          "name": "==",
+          "printedName": "==(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2eeoiySbx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "!=",
+          "printedName": "!=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2neoiySbx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE1loiySbx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2leoiySbx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2geoiySbx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE1goiySbx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BinaryInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "!=",
+          "printedName": "!=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2neoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2leoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2geoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE1goiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:Sz",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : CustomStringConvertible, τ_0_0 : Hashable, τ_0_0 : Numeric, τ_0_0 : Strideable, τ_0_0.Magnitude : BinaryInteger, τ_0_0.Magnitude == τ_0_0.Magnitude.Magnitude, τ_0_0.Words : RandomAccessCollection, τ_0_0.Words.Element == UInt, τ_0_0.Words.Index == Int>",
+      "conformingProtocols": [
+        "Hashable",
+        "Numeric",
+        "CustomStringConvertible",
+        "Strideable",
+        "Equatable",
+        "ExpressibleByIntegerLiteral",
+        "Comparable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "FixedWidthInteger",
       "printedName": "FixedWidthInteger",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "bitWidth",
+          "printedName": "bitWidth",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerP03bitB0SivgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerP03bitB0SivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "max",
+          "printedName": "max",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerP3maxxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerP3maxxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "min",
+          "printedName": "min",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerP3minxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerP3minxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "addingReportingOverflow",
+          "printedName": "addingReportingOverflow(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(partialValue: τ_0_0, overflow: Bool)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP23addingReportingOverflowyx12partialValue_Sb8overflowtxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "subtractingReportingOverflow",
+          "printedName": "subtractingReportingOverflow(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(partialValue: τ_0_0, overflow: Bool)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP28subtractingReportingOverflowyx12partialValue_Sb8overflowtxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "multipliedReportingOverflow",
+          "printedName": "multipliedReportingOverflow(by:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(partialValue: τ_0_0, overflow: Bool)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP27multipliedReportingOverflow2byx12partialValue_Sb8overflowtx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "dividedReportingOverflow",
+          "printedName": "dividedReportingOverflow(by:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(partialValue: τ_0_0, overflow: Bool)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP24dividedReportingOverflow2byx12partialValue_Sb8overflowtx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "remainderReportingOverflow",
+          "printedName": "remainderReportingOverflow(dividingBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(partialValue: τ_0_0, overflow: Bool)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP26remainderReportingOverflow10dividingByx12partialValue_Sb8overflowtx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "multipliedFullWidth",
+          "printedName": "multipliedFullWidth(by:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(high: τ_0_0, low: τ_0_0.Magnitude)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Magnitude"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP014multipliedFullB02byx4high_9MagnitudeQz3lowtx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "dividingFullWidth",
+          "printedName": "dividingFullWidth(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(quotient: τ_0_0, remainder: τ_0_0)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(high: τ_0_0, low: τ_0_0.Magnitude)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Magnitude"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP012dividingFullB0yx8quotient_x9remaindertx4high_9MagnitudeQz3lowt_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "nonzeroBitCount",
+          "printedName": "nonzeroBitCount",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerP15nonzeroBitCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerP15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "leadingZeroBitCount",
+          "printedName": "leadingZeroBitCount",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerP19leadingZeroBitCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerP19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(bigEndian:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerP9bigEndianxx_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(littleEndian:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerP12littleEndianxx_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "bigEndian",
+          "printedName": "bigEndian",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerP9bigEndianxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerP9bigEndianxvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "littleEndian",
+          "printedName": "littleEndian",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerP12littleEndianxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerP12littleEndianxvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "byteSwapped",
+          "printedName": "byteSwapped",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerP11byteSwappedxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerP11byteSwappedxvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP3aggoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP4aggeoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP3alloiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP4alleoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:radix:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "hasDefaultArg": true,
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerPsE_5radixxSgqd___SitcSyRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_1_0 : StringProtocol>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerPsEyxSgSScfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "declAttributes": [
+            "Inline",
+            "Semantics",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "bitWidth",
+          "printedName": "bitWidth",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerPsE03bitB0Sivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerPsE03bitB0Sivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(littleEndian:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerPsE12littleEndianxx_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(bigEndian:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerPsE9bigEndianxx_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "littleEndian",
+          "printedName": "littleEndian",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerPsE12littleEndianxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerPsE12littleEndianxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "bigEndian",
+          "printedName": "bigEndian",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerPsE9bigEndianxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerPsE9bigEndianxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3aggoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3aggoiyxx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE4aggeoiyyxz_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3alloiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3alloiyxx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE4alleoiyyxz_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "random",
+          "printedName": "random(in:using:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE6random2in5usingxSnyxG_qd__ztSGRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_1_0 : RandomNumberGenerator>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "random",
+          "printedName": "random(in:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE6random2inxSnyxG_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "random",
+          "printedName": "random(in:using:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SN"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE6random2in5usingxSNyxG_qd__ztSGRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_1_0 : RandomNumberGenerator>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "random",
+          "printedName": "random(in:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SN"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE6random2inxSNyxG_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "~",
+          "printedName": "~(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE1topyxxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">>",
+          "printedName": ">>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE2ggoiyxx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">>=",
+          "printedName": ">>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3ggeoiyyxz_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Semantics",
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<<",
+          "printedName": "<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE2lloiyxx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<<=",
+          "printedName": "<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3lleoiyyxz_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_1_0 : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Semantics",
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerPsEyxqd__cSBRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_1_0 : BinaryFloatingPoint>",
+          "declAttributes": [
+            "Inline",
+            "Semantics",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerPsE7exactlyxSgqd___tcSBRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_1_0 : BinaryFloatingPoint>",
+          "declAttributes": [
+            "Inlinable",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(clamping:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerPsE8clampingxqd___tcSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_1_0 : BinaryInteger>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(truncatingIfNeeded:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerPsE18truncatingIfNeededxqd___tcSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_1_0 : BinaryInteger>",
+          "declAttributes": [
+            "Inline"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&+",
+          "printedName": "&+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE2apoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&+=",
+          "printedName": "&+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3apeoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&-",
+          "printedName": "&-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE2asoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&-=",
+          "printedName": "&-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3aseoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&*",
+          "printedName": "&*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE2amoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&*=",
+          "printedName": "&*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3ameoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        }
+      ],
       "declKind": "Protocol",
       "usr": "s:s17FixedWidthIntegerP",
-      "location": "",
       "moduleName": "Swift",
-      "genericSig": "<Self : BinaryInteger, Self : LosslessStringConvertible, Self.Magnitude : FixedWidthInteger, Self.Magnitude : UnsignedInteger, Self.Stride : FixedWidthInteger, Self.Stride : SignedInteger>",
+      "genericSig": "<τ_0_0 : BinaryInteger, τ_0_0 : LosslessStringConvertible, τ_0_0.Magnitude : FixedWidthInteger, τ_0_0.Magnitude : UnsignedInteger, τ_0_0.Stride : FixedWidthInteger, τ_0_0.Stride : SignedInteger>",
       "conformingProtocols": [
         "BinaryInteger",
         "LosslessStringConvertible",
@@ -47168,1519 +48759,51 @@
         "Equatable",
         "ExpressibleByIntegerLiteral",
         "Comparable"
-      ],
-      "children": [
-        {
-          "kind": "Var",
-          "name": "bitWidth",
-          "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerP03bitB0SivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerP03bitB0SivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "max",
-          "printedName": "max",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerP3maxxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerP3maxxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "min",
-          "printedName": "min",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerP3minxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerP3minxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "addingReportingOverflow",
-          "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerP23addingReportingOverflowyx12partialValue_Sb8overflowtxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(partialValue: Self, overflow: Bool)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "subtractingReportingOverflow",
-          "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerP28subtractingReportingOverflowyx12partialValue_Sb8overflowtxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(partialValue: Self, overflow: Bool)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "multipliedReportingOverflow",
-          "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerP27multipliedReportingOverflow2byx12partialValue_Sb8overflowtx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(partialValue: Self, overflow: Bool)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "dividedReportingOverflow",
-          "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerP24dividedReportingOverflow2byx12partialValue_Sb8overflowtx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(partialValue: Self, overflow: Bool)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "remainderReportingOverflow",
-          "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerP26remainderReportingOverflow10dividingByx12partialValue_Sb8overflowtx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(partialValue: Self, overflow: Bool)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "multipliedFullWidth",
-          "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerP014multipliedFullB02byx4high_9MagnitudeQz3lowtx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(high: Self, low: Self.Magnitude)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Magnitude"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "dividingFullWidth",
-          "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerP012dividingFullB0yx8quotient_x9remaindertx4high_9MagnitudeQz3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(quotient: Self, remainder: Self)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(high: Self, low: Self.Magnitude)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Magnitude"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "nonzeroBitCount",
-          "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerP15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerP15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "leadingZeroBitCount",
-          "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerP19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerP19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(bigEndian:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerP9bigEndianxx_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(littleEndian:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerP12littleEndianxx_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "bigEndian",
-          "printedName": "bigEndian",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerP9bigEndianxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerP9bigEndianxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "littleEndian",
-          "printedName": "littleEndian",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerP12littleEndianxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerP12littleEndianxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "byteSwapped",
-          "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerP11byteSwappedxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerP11byteSwappedxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:radix:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerPsE_5radixxSgqd___SitcSyRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, S where Self : FixedWidthInteger, S : StringProtocol>",
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "hasDefaultArg": true,
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerPsEyxSgSScfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "declAttributes": [
-            "Inline",
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "bitWidth",
-          "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerPsE03bitB0Sivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerPsE03bitB0Sivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(littleEndian:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerPsE12littleEndianxx_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(bigEndian:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerPsE9bigEndianxx_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "littleEndian",
-          "printedName": "littleEndian",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerPsE12littleEndianxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerPsE12littleEndianxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "bigEndian",
-          "printedName": "bigEndian",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerPsE9bigEndianxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerPsE9bigEndianxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "random",
-          "printedName": "random(in:using:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE6random2in5usingxSnyxG_qd__ztSGRd__lFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : FixedWidthInteger, T : RandomNumberGenerator>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Self>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "random",
-          "printedName": "random(in:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE6random2inxSnyxG_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Self>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "random",
-          "printedName": "random(in:using:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE6random2in5usingxSNyxG_qd__ztSGRd__lFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : FixedWidthInteger, T : RandomNumberGenerator>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "ClosedRange",
-              "printedName": "ClosedRange<Self>",
-              "usr": "s:SN",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "random",
-          "printedName": "random(in:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE6random2inxSNyxG_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "ClosedRange",
-              "printedName": "ClosedRange<Self>",
-              "usr": "s:SN",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerPsEyxqd__cSBRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : FixedWidthInteger, T : BinaryFloatingPoint>",
-          "declAttributes": [
-            "Inline",
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerPsE7exactlyxSgqd___tcSBRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : FixedWidthInteger, T : BinaryFloatingPoint>",
-          "declAttributes": [
-            "Inline",
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(clamping:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerPsE8clampingxqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Other where Self : FixedWidthInteger, Other : BinaryInteger>",
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Other"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "unsafeAdding",
-          "printedName": "unsafeAdding(_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE12unsafeAddingyxxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "unsafeSubtracting",
-          "printedName": "unsafeSubtracting(_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE17unsafeSubtractingyxxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "unsafeMultiplied",
-          "printedName": "unsafeMultiplied(by:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE16unsafeMultiplied2byxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "unsafeDivided",
-          "printedName": "unsafeDivided(by:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE13unsafeDivided2byxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingIfNeeded:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerPsE18truncatingIfNeededxqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : FixedWidthInteger, T : BinaryInteger>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "addWithOverflow",
-          "printedName": "addWithOverflow(_:_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE15addWithOverflowyx_Sb8overflowtx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(Self, overflow: Bool)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "subtractWithOverflow",
-          "printedName": "subtractWithOverflow(_:_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE20subtractWithOverflowyx_Sb8overflowtx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(Self, overflow: Bool)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "multiplyWithOverflow",
-          "printedName": "multiplyWithOverflow(_:_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE20multiplyWithOverflowyx_Sb8overflowtx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(Self, overflow: Bool)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "divideWithOverflow",
-          "printedName": "divideWithOverflow(_:_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE18divideWithOverflowyx_Sb8overflowtx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(Self, overflow: Bool)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "remainderWithOverflow",
-          "printedName": "remainderWithOverflow(_:_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE21remainderWithOverflowyx_Sb8overflowtx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(Self, overflow: Bool)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "allZeros",
-          "printedName": "allZeros",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerPsE8allZerosxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerPsE8allZerosxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        }
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnsignedInteger",
       "printedName": "UnsignedInteger",
-      "declKind": "Protocol",
-      "usr": "s:SU",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : BinaryInteger>",
-      "conformingProtocols": [
-        "BinaryInteger",
-        "Hashable",
-        "Numeric",
-        "CustomStringConvertible",
-        "Strideable",
-        "Equatable",
-        "ExpressibleByIntegerLiteral",
-        "Comparable"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:SUsE9magnitudexvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SUsE9magnitudexvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : UnsignedInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SUsE9magnitudexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : UnsignedInteger>",
+              "declAttributes": [
+                "Inline"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SUsE9magnitudexvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "isSigned",
           "printedName": "isSigned",
-          "declKind": "Var",
-          "usr": "s:SUsE8isSignedSbvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -48692,12 +48815,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SUsE8isSignedSbvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : UnsignedInteger>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -48705,180 +48822,431 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SUsE8isSignedSbvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : UnsignedInteger>",
+              "static": true,
+              "declAttributes": [
+                "Inline"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SUsE8isSignedSbvpZ",
+          "moduleName": "Swift",
+          "static": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SUss17FixedWidthIntegerRzrlEyxqd__cSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : FixedWidthInteger, Self : UnsignedInteger, T : BinaryInteger>",
-          "declAttributes": [
-            "Inline",
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SUss17FixedWidthIntegerRzrlEyxqd__cSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_0_0 : UnsignedInteger, τ_1_0 : BinaryInteger>",
+          "declAttributes": [
+            "Inline",
+            "Semantics"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:SUss17FixedWidthIntegerRzrlE7exactlyxSgqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : FixedWidthInteger, Self : UnsignedInteger, T : BinaryInteger>",
-          "declAttributes": [
-            "Inline",
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SUss17FixedWidthIntegerRzrlE7exactlyxSgqd___tcSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_0_0 : UnsignedInteger, τ_1_0 : BinaryInteger>",
+          "declAttributes": [
+            "Inline",
+            "Semantics"
           ]
         },
         {
           "kind": "Var",
           "name": "max",
           "printedName": "max",
-          "declKind": "Var",
-          "usr": "s:SUss17FixedWidthIntegerRzrlE3maxxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SUss17FixedWidthIntegerRzrlE3maxxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger, Self : UnsignedInteger>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SUss17FixedWidthIntegerRzrlE3maxxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger, τ_0_0 : UnsignedInteger>",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SUss17FixedWidthIntegerRzrlE3maxxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "min",
           "printedName": "min",
-          "declKind": "Var",
-          "usr": "s:SUss17FixedWidthIntegerRzrlE3minxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SUss17FixedWidthIntegerRzrlE3minxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger, Self : UnsignedInteger>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SUss17FixedWidthIntegerRzrlE3minxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger, τ_0_0 : UnsignedInteger>",
+              "static": true
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "toUIntMax",
-          "printedName": "toUIntMax()",
-          "declKind": "Func",
-          "usr": "s:SUsE9toUIntMaxs6UInt64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnsignedInteger>",
-          "declAttributes": [
-            "Available"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
+          "declKind": "Var",
+          "usr": "s:SUss17FixedWidthIntegerRzrlE3minxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SU",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : BinaryInteger>",
+      "conformingProtocols": [
+        "BinaryInteger",
+        "Hashable",
+        "Numeric",
+        "CustomStringConvertible",
+        "Strideable",
+        "Equatable",
+        "ExpressibleByIntegerLiteral",
+        "Comparable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "SignedInteger",
       "printedName": "SignedInteger",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "isSigned",
+          "printedName": "isSigned",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SZsE8isSignedSbvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : SignedInteger>",
+              "static": true,
+              "declAttributes": [
+                "Inline"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SZsE8isSignedSbvpZ",
+          "moduleName": "Swift",
+          "static": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SZss17FixedWidthIntegerRzrlEyxqd__cSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_0_0 : SignedInteger, τ_1_0 : BinaryInteger>",
+          "declAttributes": [
+            "Inline",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SZss17FixedWidthIntegerRzrlE7exactlyxSgqd___tcSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : FixedWidthInteger, τ_0_0 : SignedInteger, τ_1_0 : BinaryInteger>",
+          "declAttributes": [
+            "Inline",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "max",
+          "printedName": "max",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SZss17FixedWidthIntegerRzrlE3maxxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger, τ_0_0 : SignedInteger>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SZss17FixedWidthIntegerRzrlE3maxxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "min",
+          "printedName": "min",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SZss17FixedWidthIntegerRzrlE3minxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger, τ_0_0 : SignedInteger>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SZss17FixedWidthIntegerRzrlE3minxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isMultiple",
+          "printedName": "isMultiple(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SZss17FixedWidthIntegerRzrlE10isMultiple2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger, τ_0_0 : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&+",
+          "printedName": "&+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SZss17FixedWidthIntegerRzrlE2apoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger, τ_0_0 : SignedInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&-",
+          "printedName": "&-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SZss17FixedWidthIntegerRzrlE2asoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : FixedWidthInteger, τ_0_0 : SignedInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        }
+      ],
       "declKind": "Protocol",
       "usr": "s:SZ",
-      "location": "",
       "moduleName": "Swift",
-      "genericSig": "<Self : BinaryInteger, Self : SignedNumeric>",
+      "genericSig": "<τ_0_0 : BinaryInteger, τ_0_0 : SignedNumeric>",
       "conformingProtocols": [
         "BinaryInteger",
         "SignedNumeric",
@@ -48889,249 +49257,41 @@
         "Equatable",
         "ExpressibleByIntegerLiteral",
         "Comparable"
-      ],
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "numericCast",
+      "printedName": "numericCast(_:)",
       "children": [
         {
-          "kind": "Var",
-          "name": "isSigned",
-          "printedName": "isSigned",
-          "declKind": "Var",
-          "usr": "s:SZsE8isSignedSbvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SZsE8isSignedSbvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : SignedInteger>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_1"
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SZss17FixedWidthIntegerRzrlEyxqd__cSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : FixedWidthInteger, Self : SignedInteger, T : BinaryInteger>",
-          "declAttributes": [
-            "Inline",
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:SZss17FixedWidthIntegerRzrlE7exactlyxSgqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : FixedWidthInteger, Self : SignedInteger, T : BinaryInteger>",
-          "declAttributes": [
-            "Inline",
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "max",
-          "printedName": "max",
-          "declKind": "Var",
-          "usr": "s:SZss17FixedWidthIntegerRzrlE3maxxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SZss17FixedWidthIntegerRzrlE3maxxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger, Self : SignedInteger>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "min",
-          "printedName": "min",
-          "declKind": "Var",
-          "usr": "s:SZss17FixedWidthIntegerRzrlE3minxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SZss17FixedWidthIntegerRzrlE3minxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger, Self : SignedInteger>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s11numericCastyq_xSzRzSzR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : BinaryInteger, τ_0_1 : BinaryInteger>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UInt8",
       "printedName": "UInt8",
-      "declKind": "Struct",
-      "usr": "s:s5UInt8V",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Comparable",
-        "UnsignedInteger",
-        "_ExpressibleByBuiltinIntegerLiteral",
-        "BinaryInteger",
-        "LosslessStringConvertible",
-        "Numeric",
-        "CustomStringConvertible",
-        "Strideable",
-        "ExpressibleByIntegerLiteral",
-        "FixedWidthInteger",
-        "Decodable",
-        "Encodable",
-        "Hashable",
-        "Equatable",
-        "_HasCustomAnyHashableRepresentation",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "_StringElement",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "IntegerLiteralType",
-          "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s5UInt8V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            }
-          ]
-        },
-        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V10bitPatternABs4Int8V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49145,25 +49305,57 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5UInt8V10bitPatternABs4Int8V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s5UInt8VyABSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
+              "name": "Optional",
+              "printedName": "Optional<UInt8>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt8",
+                  "printedName": "UInt8",
+                  "usr": "s:s5UInt8V"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -49171,85 +49363,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:s5UInt8V7exactlyABSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UInt8?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt8",
-                  "printedName": "UInt8",
-                  "usr": "s:s5UInt8V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s5UInt8VyABSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49257,7 +49412,8 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -49265,19 +49421,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5UInt8V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8VyABs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49291,25 +49446,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5UInt8VyABs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V7exactlyABSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49317,7 +49470,8 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -49325,19 +49479,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5UInt8V7exactlyABSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49364,19 +49705,18 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49403,19 +49743,18 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49442,19 +49781,18 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49481,19 +49819,18 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49520,20 +49857,204 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2reoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2aeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2oeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2xeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V4aggeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V4alleoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49545,11 +50066,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49557,21 +50073,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49583,10 +50103,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49594,21 +50110,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49620,10 +50138,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49631,21 +50145,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49657,10 +50173,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49668,88 +50180,71 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:s5UInt8V5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:s5UInt8V5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Var",
+              "name": "_value",
+              "printedName": "_value",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Int>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s5UInt8V5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                  "name": "UInt8",
+                  "printedName": "UInt8",
+                  "usr": "s:s5UInt8V"
+                },
                 {
-                  "kind": "TypeNominal",
-                  "name": "Slice",
-                  "printedName": "Slice<UInt8.Words>",
-                  "usr": "s:s5SliceV",
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "UInt8.Words",
-                      "usr": "s:s5UInt8V5WordsV"
+                      "name": "UInt8",
+                      "printedName": "UInt8",
+                      "usr": "s:s5UInt8V"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5UInt8V5WordsV6_valueABvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s5UInt8V5WordsV6_valueABvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s5UInt8V5WordsVyAdBcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49763,19 +50258,18 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s5UInt8V5WordsVyAdBcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:s5UInt8V5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49787,10 +50281,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5UInt8V5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -49798,21 +50288,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5UInt8V5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5UInt8V5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:s5UInt8V5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49824,10 +50316,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5UInt8V5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -49835,21 +50323,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5UInt8V5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5UInt8V5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:s5UInt8V5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49861,10 +50351,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5UInt8V5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -49872,32 +50358,47 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5UInt8V5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5UInt8V5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:s5UInt8V5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "UInt8.Words.Indices",
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Int>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -49905,55 +50406,26 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
+                  ],
                   "declKind": "Accessor",
                   "usr": "s:s5UInt8V5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Indices",
-                      "printedName": "UInt8.Words.Indices",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Range",
-                          "printedName": "Range<Int>",
-                          "usr": "s:Sn",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Int",
-                              "printedName": "Int",
-                              "usr": "s:Si"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5UInt8V5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:s5UInt8V5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49967,19 +50439,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s5UInt8V5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:s5UInt8V5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49993,80 +50464,57 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s5UInt8V5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s5UInt8V5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UInt",
                   "printedName": "UInt",
                   "usr": "s:Su"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:s5UInt8V5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                },
                 {
                   "kind": "TypeNominal",
                   "name": "Int",
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s5UInt8V5WordsV8Iteratora",
-              "location": "",
+              ],
+              "declKind": "Subscript",
+              "usr": "s:s5UInt8V5WordsVySuSicip",
               "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<UInt8.Words>",
-                  "usr": "s:s16IndexingIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "UInt8.Words",
-                      "usr": "s:s5UInt8V5WordsV"
-                    }
-                  ]
-                }
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s5UInt8V5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V5wordsAB5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50078,10 +50526,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V5wordsAB5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50089,43 +50533,28 @@
                   "printedName": "UInt8.Words",
                   "usr": "s:s5UInt8V5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V5wordsAB5WordsVvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Magnitude",
-          "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s5UInt8V9Magnitudea",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V5wordsAB5WordsVvp",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            }
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V19multipliedFullWidth2byAB4high_AB3lowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: UInt8, low: UInt8.Magnitude)",
+              "printedName": "(high: UInt8, low: UInt8)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50134,17 +50563,10 @@
                   "usr": "s:s5UInt8V"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "UInt8.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt8",
-                      "printedName": "UInt8",
-                      "usr": "s:s5UInt8V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt8",
+                  "printedName": "UInt8",
+                  "usr": "s:s5UInt8V"
                 }
               ]
             },
@@ -50154,19 +50576,18 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V19multipliedFullWidth2byAB4high_AB3lowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_AB3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50190,7 +50611,7 @@
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: UInt8, low: UInt8.Magnitude)",
+              "printedName": "(high: UInt8, low: UInt8)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50199,33 +50620,25 @@
                   "usr": "s:s5UInt8V"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "UInt8.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt8",
-                      "printedName": "UInt8",
-                      "usr": "s:s5UInt8V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt8",
+                  "printedName": "UInt8",
+                  "usr": "s:s5UInt8V"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_AB3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V11byteSwappedABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50237,10 +50650,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V11byteSwappedABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50248,43 +50657,84 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V11byteSwappedABvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V11byteSwappedABvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Function",
-          "name": "toIntMax",
-          "printedName": "toIntMax()",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V8toIntMaxs5Int64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Var",
+          "name": "_value",
+          "printedName": "_value",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "BuiltinInteger",
+              "printedName": "Builtin.Int8"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int8"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V6_valueBi8_vg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int8"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V6_valueBi8_vs",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V6_valueBi8_vp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "hasStorage": true
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V6signumAByF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50292,37 +50742,19 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s5UInt8V6Stridea",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V6signumAByF",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V4fromABs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50336,20 +50768,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5UInt8V4fromABs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50362,19 +50790,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50387,16 +50812,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50408,10 +50835,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50419,23 +50842,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V20truncatingBitPatternABs6UInt16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50445,25 +50867,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1aoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V20truncatingBitPatternABs5Int16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50473,25 +50899,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1ooiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V20truncatingBitPatternABs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50501,25 +50931,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1xoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V20truncatingBitPatternABs5Int32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50529,25 +50963,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V3aggoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V20truncatingBitPatternABs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50557,25 +50995,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V3alloiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V20truncatingBitPatternABs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50585,25 +51027,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V20truncatingBitPatternABSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50613,25 +51059,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1roiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V20truncatingBitPatternABSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50641,23 +51091,189 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2leoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2geoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1goiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(ascii:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V5asciiABs7UnicodeO6ScalarV_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50671,16 +51287,18 @@
               "printedName": "Unicode.Scalar",
               "usr": "s:s7UnicodeO6ScalarV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5UInt8V5asciiABs7UnicodeO6ScalarV_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50692,10 +51310,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50703,23 +51317,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V25customPlaygroundQuickLooks01_cdE0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50731,10 +51342,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V25customPlaygroundQuickLooks01_cdE0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50742,73 +51349,58 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V25customPlaygroundQuickLooks01_cdE0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V25customPlaygroundQuickLooks01_cdE0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s5UInt8V",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Comparable",
+        "UnsignedInteger",
+        "_ExpressibleByBuiltinIntegerLiteral",
+        "BinaryInteger",
+        "LosslessStringConvertible",
+        "Numeric",
+        "CustomStringConvertible",
+        "Strideable",
+        "ExpressibleByIntegerLiteral",
+        "FixedWidthInteger",
+        "Encodable",
+        "Decodable",
+        "Hashable",
+        "Equatable",
+        "_HasCustomAnyHashableRepresentation",
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "_StringElement",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Int8",
       "printedName": "Int8",
-      "declKind": "Struct",
-      "usr": "s:s4Int8V",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Comparable",
-        "SignedInteger",
-        "_ExpressibleByBuiltinIntegerLiteral",
-        "BinaryInteger",
-        "LosslessStringConvertible",
-        "SignedNumeric",
-        "Numeric",
-        "CustomStringConvertible",
-        "Strideable",
-        "ExpressibleByIntegerLiteral",
-        "FixedWidthInteger",
-        "Decodable",
-        "Encodable",
-        "Hashable",
-        "Equatable",
-        "_HasCustomAnyHashableRepresentation",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "IntegerLiteralType",
-          "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s4Int8V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
-            }
-          ]
-        },
-        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V10bitPatternABs5UInt8V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50822,25 +51414,57 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s4Int8V10bitPatternABs5UInt8V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s4Int8VyABSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
+              "name": "Optional",
+              "printedName": "Optional<Int8>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int8",
+                  "printedName": "Int8",
+                  "usr": "s:s4Int8V"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -50848,85 +51472,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:s4Int8V7exactlyABSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Int8?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int8",
-                  "printedName": "Int8",
-                  "usr": "s:s4Int8V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s4Int8VyABSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50934,7 +51521,8 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -50942,19 +51530,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s4Int8V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8VyABs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50968,25 +51555,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s4Int8VyABs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V7exactlyABSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int8?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int8>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50994,7 +51579,8 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -51002,19 +51588,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s4Int8V7exactlyABSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51041,19 +51814,18 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51080,19 +51852,18 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51119,19 +51890,18 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51158,19 +51928,18 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51197,20 +51966,204 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2reoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2aeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2oeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2xeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V4aggeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V4alleoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s4Int8V8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51222,11 +52175,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51234,21 +52182,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s4Int8V19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51260,10 +52212,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51271,21 +52219,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s4Int8V20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51297,10 +52247,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51308,21 +52254,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s4Int8V15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51334,10 +52282,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51345,88 +52289,71 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:s4Int8V5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:s4Int8V5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Var",
+              "name": "_value",
+              "printedName": "_value",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Int>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s4Int8V5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                  "name": "Int8",
+                  "printedName": "Int8",
+                  "usr": "s:s4Int8V"
+                },
                 {
-                  "kind": "TypeNominal",
-                  "name": "Slice",
-                  "printedName": "Slice<Int8.Words>",
-                  "usr": "s:s5SliceV",
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "Int8.Words",
-                      "usr": "s:s4Int8V5WordsV"
+                      "name": "Int8",
+                      "printedName": "Int8",
+                      "usr": "s:s4Int8V"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s4Int8V5WordsV6_valueABvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s4Int8V5WordsV6_valueABvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s4Int8V5WordsVyAdBcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51440,19 +52367,18 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s4Int8V5WordsVyAdBcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:s4Int8V5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51464,10 +52390,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s4Int8V5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -51475,21 +52397,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s4Int8V5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s4Int8V5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:s4Int8V5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51501,10 +52425,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s4Int8V5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -51512,21 +52432,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s4Int8V5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s4Int8V5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:s4Int8V5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51538,10 +52460,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s4Int8V5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -51549,32 +52467,47 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s4Int8V5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s4Int8V5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:s4Int8V5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "Int8.Words.Indices",
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Int>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -51582,55 +52515,26 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
+                  ],
                   "declKind": "Accessor",
                   "usr": "s:s4Int8V5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Indices",
-                      "printedName": "Int8.Words.Indices",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Range",
-                          "printedName": "Range<Int>",
-                          "usr": "s:Sn",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Int",
-                              "printedName": "Int",
-                              "usr": "s:Si"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s4Int8V5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:s4Int8V5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51644,19 +52548,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s4Int8V5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:s4Int8V5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51670,80 +52573,57 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s4Int8V5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s4Int8V5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UInt",
                   "printedName": "UInt",
                   "usr": "s:Su"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:s4Int8V5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                },
                 {
                   "kind": "TypeNominal",
                   "name": "Int",
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s4Int8V5WordsV8Iteratora",
-              "location": "",
+              ],
+              "declKind": "Subscript",
+              "usr": "s:s4Int8V5WordsVySuSicip",
               "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<Int8.Words>",
-                  "usr": "s:s16IndexingIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "Int8.Words",
-                      "usr": "s:s4Int8V5WordsV"
-                    }
-                  ]
-                }
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s4Int8V5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:s4Int8V5wordsAB5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51755,10 +52635,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V5wordsAB5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51766,38 +52642,23 @@
                   "printedName": "Int8.Words",
                   "usr": "s:s4Int8V5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V5wordsAB5WordsVvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Magnitude",
-          "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s4Int8V9Magnitudea",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V5wordsAB5WordsVvp",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            }
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:s4Int8V9magnitudes5UInt8Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51809,10 +52670,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V9magnitudes5UInt8Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51820,26 +52677,28 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V9magnitudes5UInt8Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V9magnitudes5UInt8Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V19multipliedFullWidth2byAB4high_s5UInt8V3lowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: Int8, low: Int8.Magnitude)",
+              "printedName": "(high: Int8, low: UInt8)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51848,17 +52707,10 @@
                   "usr": "s:s4Int8V"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "Int8.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt8",
-                      "printedName": "UInt8",
-                      "usr": "s:s5UInt8V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt8",
+                  "printedName": "UInt8",
+                  "usr": "s:s5UInt8V"
                 }
               ]
             },
@@ -51868,19 +52720,18 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V19multipliedFullWidth2byAB4high_s5UInt8V3lowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_s5UInt8V3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51904,7 +52755,7 @@
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: Int8, low: Int8.Magnitude)",
+              "printedName": "(high: Int8, low: UInt8)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51913,33 +52764,25 @@
                   "usr": "s:s4Int8V"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "Int8.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt8",
-                      "printedName": "UInt8",
-                      "usr": "s:s5UInt8V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt8",
+                  "printedName": "UInt8",
+                  "usr": "s:s5UInt8V"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_s5UInt8V3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s4Int8V11byteSwappedABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51951,10 +52794,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V11byteSwappedABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51962,43 +52801,84 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V11byteSwappedABvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V11byteSwappedABvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Function",
-          "name": "toUIntMax",
-          "printedName": "toUIntMax()",
-          "declKind": "Func",
-          "usr": "s:s4Int8V9toUIntMaxs6UInt64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Var",
+          "name": "_value",
+          "printedName": "_value",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "BuiltinInteger",
+              "printedName": "Builtin.Int8"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int8"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V6_valueBi8_vg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int8"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V6_valueBi8_vs",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V6_valueBi8_vp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "hasStorage": true
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:s4Int8V6signumAByF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52006,37 +52886,19 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s4Int8V6Stridea",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V6signumAByF",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V4fromABs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52050,20 +52912,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s4Int8V4fromABs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52076,19 +52934,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52101,16 +52956,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s4Int8V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52122,10 +52979,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -52133,23 +52986,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V20truncatingBitPatternABs6UInt16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52159,25 +53011,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1aoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V20truncatingBitPatternABs5Int16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52187,25 +53043,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1ooiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V20truncatingBitPatternABs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52215,25 +53075,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1xoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V20truncatingBitPatternABs5Int32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52243,25 +53107,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V3aggoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V20truncatingBitPatternABs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52271,25 +53139,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V3alloiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V20truncatingBitPatternABs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52299,25 +53171,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V20truncatingBitPatternABSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52327,25 +53203,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1roiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V20truncatingBitPatternABSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52355,20 +53235,189 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2leoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2geoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1goiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s4Int8V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52380,10 +53429,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -52391,23 +53436,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:s4Int8V25customPlaygroundQuickLooks01_cdE0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52419,10 +53461,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V25customPlaygroundQuickLooks01_cdE0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -52430,73 +53468,58 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V25customPlaygroundQuickLooks01_cdE0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V25customPlaygroundQuickLooks01_cdE0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s4Int8V",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Comparable",
+        "SignedInteger",
+        "_ExpressibleByBuiltinIntegerLiteral",
+        "BinaryInteger",
+        "LosslessStringConvertible",
+        "SignedNumeric",
+        "Numeric",
+        "CustomStringConvertible",
+        "Strideable",
+        "ExpressibleByIntegerLiteral",
+        "FixedWidthInteger",
+        "Encodable",
+        "Decodable",
+        "Hashable",
+        "Equatable",
+        "_HasCustomAnyHashableRepresentation",
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UInt16",
       "printedName": "UInt16",
-      "declKind": "Struct",
-      "usr": "s:s6UInt16V",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Comparable",
-        "UnsignedInteger",
-        "_ExpressibleByBuiltinIntegerLiteral",
-        "BinaryInteger",
-        "LosslessStringConvertible",
-        "Numeric",
-        "CustomStringConvertible",
-        "Strideable",
-        "ExpressibleByIntegerLiteral",
-        "FixedWidthInteger",
-        "Decodable",
-        "Encodable",
-        "Hashable",
-        "Equatable",
-        "_HasCustomAnyHashableRepresentation",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "_StringElement",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "IntegerLiteralType",
-          "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt16V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            }
-          ]
-        },
-        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V10bitPatternABs5Int16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52510,25 +53533,57 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt16V10bitPatternABs5Int16V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt16VyABSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
+              "name": "Optional",
+              "printedName": "Optional<UInt16>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt16",
+                  "printedName": "UInt16",
+                  "usr": "s:s6UInt16V"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -52536,85 +53591,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt16V7exactlyABSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UInt16?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt16",
-                  "printedName": "UInt16",
-                  "usr": "s:s6UInt16V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt16VyABSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -52622,7 +53640,8 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -52630,19 +53649,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt16V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16VyABs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52656,25 +53674,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt16VyABs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V7exactlyABSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -52682,7 +53698,8 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -52690,19 +53707,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt16V7exactlyABSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52729,19 +53933,18 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52768,19 +53971,18 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52807,19 +54009,18 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52846,19 +54047,18 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52885,20 +54085,204 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2reoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2aeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2oeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2xeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V4aggeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V4alleoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52910,11 +54294,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -52922,21 +54301,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52948,10 +54331,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -52959,21 +54338,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52985,10 +54366,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -52996,21 +54373,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -53022,10 +54401,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53033,88 +54408,71 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:s6UInt16V5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt16V5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Var",
+              "name": "_value",
+              "printedName": "_value",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Int>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt16V5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                  "name": "UInt16",
+                  "printedName": "UInt16",
+                  "usr": "s:s6UInt16V"
+                },
                 {
-                  "kind": "TypeNominal",
-                  "name": "Slice",
-                  "printedName": "Slice<UInt16.Words>",
-                  "usr": "s:s5SliceV",
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "UInt16.Words",
-                      "usr": "s:s6UInt16V5WordsV"
+                      "name": "UInt16",
+                      "printedName": "UInt16",
+                      "usr": "s:s6UInt16V"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt16V5WordsV6_valueABvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt16V5WordsV6_valueABvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s6UInt16V5WordsVyAdBcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53128,19 +54486,18 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s6UInt16V5WordsVyAdBcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:s6UInt16V5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53152,10 +54509,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt16V5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -53163,21 +54516,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt16V5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt16V5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:s6UInt16V5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53189,10 +54544,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt16V5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -53200,21 +54551,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt16V5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt16V5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:s6UInt16V5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53226,10 +54579,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt16V5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -53237,32 +54586,47 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt16V5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt16V5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:s6UInt16V5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "UInt16.Words.Indices",
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Int>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -53270,55 +54634,26 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
+                  ],
                   "declKind": "Accessor",
                   "usr": "s:s6UInt16V5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Indices",
-                      "printedName": "UInt16.Words.Indices",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Range",
-                          "printedName": "Range<Int>",
-                          "usr": "s:Sn",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Int",
-                              "printedName": "Int",
-                              "usr": "s:Si"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt16V5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:s6UInt16V5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53332,19 +54667,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s6UInt16V5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:s6UInt16V5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53358,80 +54692,57 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s6UInt16V5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt16V5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UInt",
                   "printedName": "UInt",
                   "usr": "s:Su"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt16V5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                },
                 {
                   "kind": "TypeNominal",
                   "name": "Int",
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt16V5WordsV8Iteratora",
-              "location": "",
+              ],
+              "declKind": "Subscript",
+              "usr": "s:s6UInt16V5WordsVySuSicip",
               "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<UInt16.Words>",
-                  "usr": "s:s16IndexingIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "UInt16.Words",
-                      "usr": "s:s6UInt16V5WordsV"
-                    }
-                  ]
-                }
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s6UInt16V5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V5wordsAB5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -53443,10 +54754,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V5wordsAB5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53454,43 +54761,28 @@
                   "printedName": "UInt16.Words",
                   "usr": "s:s6UInt16V5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V5wordsAB5WordsVvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Magnitude",
-          "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt16V9Magnitudea",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V5wordsAB5WordsVvp",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            }
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V19multipliedFullWidth2byAB4high_AB3lowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: UInt16, low: UInt16.Magnitude)",
+              "printedName": "(high: UInt16, low: UInt16)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53499,17 +54791,10 @@
                   "usr": "s:s6UInt16V"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "UInt16.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt16",
-                      "printedName": "UInt16",
-                      "usr": "s:s6UInt16V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt16",
+                  "printedName": "UInt16",
+                  "usr": "s:s6UInt16V"
                 }
               ]
             },
@@ -53519,19 +54804,18 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V19multipliedFullWidth2byAB4high_AB3lowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_AB3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -53555,7 +54839,7 @@
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: UInt16, low: UInt16.Magnitude)",
+              "printedName": "(high: UInt16, low: UInt16)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53564,33 +54848,25 @@
                   "usr": "s:s6UInt16V"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "UInt16.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt16",
-                      "printedName": "UInt16",
-                      "usr": "s:s6UInt16V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt16",
+                  "printedName": "UInt16",
+                  "usr": "s:s6UInt16V"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_AB3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V11byteSwappedABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -53602,10 +54878,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V11byteSwappedABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53613,43 +54885,84 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V11byteSwappedABvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V11byteSwappedABvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Function",
-          "name": "toIntMax",
-          "printedName": "toIntMax()",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V8toIntMaxs5Int64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Var",
+          "name": "_value",
+          "printedName": "_value",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "BuiltinInteger",
+              "printedName": "Builtin.Int16"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int16"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V6_valueBi16_vg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int16"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V6_valueBi16_vs",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V6_valueBi16_vp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "hasStorage": true
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V6signumAByF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -53657,37 +54970,19 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt16V6Stridea",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V6signumAByF",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V4fromABs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -53701,20 +54996,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt16V4fromABs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -53727,19 +55018,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -53752,16 +55040,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53773,10 +55063,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53784,23 +55070,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V20truncatingBitPatternABs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53810,25 +55095,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1aoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V20truncatingBitPatternABs5Int32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53838,25 +55127,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1ooiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V20truncatingBitPatternABs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53866,25 +55159,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1xoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V20truncatingBitPatternABs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53894,25 +55191,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V3aggoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V20truncatingBitPatternABSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53922,25 +55223,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V3alloiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V20truncatingBitPatternABSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53950,20 +55255,253 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1roiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2leoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2geoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1goiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53975,10 +55513,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53986,23 +55520,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V25customPlaygroundQuickLooks01_cdE0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54014,10 +55545,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V25customPlaygroundQuickLooks01_cdE0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54025,73 +55552,58 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V25customPlaygroundQuickLooks01_cdE0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V25customPlaygroundQuickLooks01_cdE0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s6UInt16V",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Comparable",
+        "UnsignedInteger",
+        "_ExpressibleByBuiltinIntegerLiteral",
+        "BinaryInteger",
+        "LosslessStringConvertible",
+        "Numeric",
+        "CustomStringConvertible",
+        "Strideable",
+        "ExpressibleByIntegerLiteral",
+        "FixedWidthInteger",
+        "Encodable",
+        "Decodable",
+        "Hashable",
+        "Equatable",
+        "_HasCustomAnyHashableRepresentation",
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "_StringElement",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Int16",
       "printedName": "Int16",
-      "declKind": "Struct",
-      "usr": "s:s5Int16V",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Comparable",
-        "SignedInteger",
-        "_ExpressibleByBuiltinIntegerLiteral",
-        "BinaryInteger",
-        "LosslessStringConvertible",
-        "SignedNumeric",
-        "Numeric",
-        "CustomStringConvertible",
-        "Strideable",
-        "ExpressibleByIntegerLiteral",
-        "FixedWidthInteger",
-        "Decodable",
-        "Encodable",
-        "Hashable",
-        "Equatable",
-        "_HasCustomAnyHashableRepresentation",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "IntegerLiteralType",
-          "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int16V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
-            }
-          ]
-        },
-        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V10bitPatternABs6UInt16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54105,25 +55617,57 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int16V10bitPatternABs6UInt16V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int16VyABSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
+              "name": "Optional",
+              "printedName": "Optional<Int16>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int16",
+                  "printedName": "Int16",
+                  "usr": "s:s5Int16V"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -54131,85 +55675,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int16V7exactlyABSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Int16?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int16",
-                  "printedName": "Int16",
-                  "usr": "s:s5Int16V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int16VyABSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54217,7 +55724,8 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -54225,19 +55733,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int16V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16VyABs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54251,25 +55758,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int16VyABs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V7exactlyABSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int16?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int16>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54277,7 +55782,8 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -54285,19 +55791,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int16V7exactlyABSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54324,19 +56017,18 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54363,19 +56055,18 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54402,19 +56093,18 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54441,19 +56131,18 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54480,20 +56169,204 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2reoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2aeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2oeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2xeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V4aggeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V4alleoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s5Int16V8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54505,11 +56378,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54517,21 +56385,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int16V19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54543,10 +56415,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54554,21 +56422,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int16V20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54580,10 +56450,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54591,21 +56457,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int16V15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54617,10 +56485,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54628,88 +56492,71 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:s5Int16V5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int16V5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Var",
+              "name": "_value",
+              "printedName": "_value",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Int>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int16V5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                  "name": "Int16",
+                  "printedName": "Int16",
+                  "usr": "s:s5Int16V"
+                },
                 {
-                  "kind": "TypeNominal",
-                  "name": "Slice",
-                  "printedName": "Slice<Int16.Words>",
-                  "usr": "s:s5SliceV",
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "Int16.Words",
-                      "usr": "s:s5Int16V5WordsV"
+                      "name": "Int16",
+                      "printedName": "Int16",
+                      "usr": "s:s5Int16V"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int16V5WordsV6_valueABvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int16V5WordsV6_valueABvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s5Int16V5WordsVyAdBcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54723,19 +56570,18 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s5Int16V5WordsVyAdBcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:s5Int16V5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54747,10 +56593,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int16V5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -54758,21 +56600,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int16V5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int16V5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:s5Int16V5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54784,10 +56628,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int16V5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -54795,21 +56635,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int16V5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int16V5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:s5Int16V5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54821,10 +56663,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int16V5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -54832,32 +56670,47 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int16V5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int16V5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:s5Int16V5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "Int16.Words.Indices",
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Int>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -54865,55 +56718,26 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
+                  ],
                   "declKind": "Accessor",
                   "usr": "s:s5Int16V5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Indices",
-                      "printedName": "Int16.Words.Indices",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Range",
-                          "printedName": "Range<Int>",
-                          "usr": "s:Sn",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Int",
-                              "printedName": "Int",
-                              "usr": "s:Si"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int16V5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:s5Int16V5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54927,19 +56751,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s5Int16V5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:s5Int16V5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54953,80 +56776,57 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s5Int16V5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int16V5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UInt",
                   "printedName": "UInt",
                   "usr": "s:Su"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int16V5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                },
                 {
                   "kind": "TypeNominal",
                   "name": "Int",
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int16V5WordsV8Iteratora",
-              "location": "",
+              ],
+              "declKind": "Subscript",
+              "usr": "s:s5Int16V5WordsVySuSicip",
               "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<Int16.Words>",
-                  "usr": "s:s16IndexingIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "Int16.Words",
-                      "usr": "s:s5Int16V5WordsV"
-                    }
-                  ]
-                }
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s5Int16V5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:s5Int16V5wordsAB5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55038,10 +56838,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V5wordsAB5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55049,38 +56845,23 @@
                   "printedName": "Int16.Words",
                   "usr": "s:s5Int16V5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V5wordsAB5WordsVvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Magnitude",
-          "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int16V9Magnitudea",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V5wordsAB5WordsVvp",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            }
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:s5Int16V9magnitudes6UInt16Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55092,10 +56873,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V9magnitudes6UInt16Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55103,26 +56880,28 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V9magnitudes6UInt16Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V9magnitudes6UInt16Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V19multipliedFullWidth2byAB4high_s6UInt16V3lowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: Int16, low: Int16.Magnitude)",
+              "printedName": "(high: Int16, low: UInt16)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55131,17 +56910,10 @@
                   "usr": "s:s5Int16V"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "Int16.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt16",
-                      "printedName": "UInt16",
-                      "usr": "s:s6UInt16V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt16",
+                  "printedName": "UInt16",
+                  "usr": "s:s6UInt16V"
                 }
               ]
             },
@@ -55151,19 +56923,18 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V19multipliedFullWidth2byAB4high_s6UInt16V3lowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_s6UInt16V3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55187,7 +56958,7 @@
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: Int16, low: Int16.Magnitude)",
+              "printedName": "(high: Int16, low: UInt16)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55196,33 +56967,25 @@
                   "usr": "s:s5Int16V"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "Int16.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt16",
-                      "printedName": "UInt16",
-                      "usr": "s:s6UInt16V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt16",
+                  "printedName": "UInt16",
+                  "usr": "s:s6UInt16V"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_s6UInt16V3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s5Int16V11byteSwappedABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55234,10 +56997,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V11byteSwappedABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55245,43 +57004,84 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V11byteSwappedABvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V11byteSwappedABvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Function",
-          "name": "toUIntMax",
-          "printedName": "toUIntMax()",
-          "declKind": "Func",
-          "usr": "s:s5Int16V9toUIntMaxs6UInt64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Var",
+          "name": "_value",
+          "printedName": "_value",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "BuiltinInteger",
+              "printedName": "Builtin.Int16"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int16"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V6_valueBi16_vg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int16"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V6_valueBi16_vs",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V6_valueBi16_vp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "hasStorage": true
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:s5Int16V6signumAByF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55289,37 +57089,19 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int16V6Stridea",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V6signumAByF",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V4fromABs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55333,20 +57115,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int16V4fromABs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55359,19 +57137,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55384,16 +57159,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s5Int16V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55405,10 +57182,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55416,23 +57189,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V20truncatingBitPatternABs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55442,25 +57214,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1aoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V20truncatingBitPatternABs5Int32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55470,25 +57246,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1ooiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V20truncatingBitPatternABs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55498,25 +57278,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1xoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V20truncatingBitPatternABs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55526,25 +57310,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V3aggoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V20truncatingBitPatternABSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55554,25 +57342,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V3alloiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V20truncatingBitPatternABSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55582,20 +57374,253 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1roiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2leoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2geoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1goiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s5Int16V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55607,10 +57632,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55618,23 +57639,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:s5Int16V25customPlaygroundQuickLooks01_cdE0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55646,10 +57664,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V25customPlaygroundQuickLooks01_cdE0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55657,72 +57671,58 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V25customPlaygroundQuickLooks01_cdE0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V25customPlaygroundQuickLooks01_cdE0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "UInt32",
-      "printedName": "UInt32",
+      ],
       "declKind": "Struct",
-      "usr": "s:s6UInt32V",
-      "location": "",
+      "usr": "s:s5Int16V",
       "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "Comparable",
-        "UnsignedInteger",
+        "SignedInteger",
         "_ExpressibleByBuiltinIntegerLiteral",
         "BinaryInteger",
         "LosslessStringConvertible",
+        "SignedNumeric",
         "Numeric",
         "CustomStringConvertible",
         "Strideable",
         "ExpressibleByIntegerLiteral",
         "FixedWidthInteger",
-        "Decodable",
         "Encodable",
+        "Decodable",
         "Hashable",
         "Equatable",
         "_HasCustomAnyHashableRepresentation",
         "CustomReflectable",
         "_CustomPlaygroundQuickLookable",
         "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "UInt32",
+      "printedName": "UInt32",
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "IntegerLiteralType",
-          "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt32V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32V10bitPatternABs5Int32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55736,25 +57736,57 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt32V10bitPatternABs5Int32V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt32VyABSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
+              "name": "Optional",
+              "printedName": "Optional<UInt32>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt32",
+                  "printedName": "UInt32",
+                  "usr": "s:s6UInt32V"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -55762,85 +57794,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt32V7exactlyABSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UInt32?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt32",
-                  "printedName": "UInt32",
-                  "usr": "s:s6UInt32V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt32VyABSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55848,7 +57843,8 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -55856,19 +57852,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt32V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32VyABs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55882,25 +57877,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt32VyABs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32V7exactlyABSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55908,7 +57901,8 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -55916,19 +57910,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt32V7exactlyABSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55955,19 +58136,18 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55994,19 +58174,18 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56033,19 +58212,18 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56072,19 +58250,18 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56111,20 +58288,204 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2reoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2aeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2oeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2xeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V4aggeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V4alleoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56136,11 +58497,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56148,21 +58504,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56174,10 +58534,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56185,21 +58541,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56211,10 +58569,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56222,21 +58576,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56248,10 +58604,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56259,88 +58611,71 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:s6UInt32V5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt32V5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Var",
+              "name": "_value",
+              "printedName": "_value",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Int>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt32V5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                  "name": "UInt32",
+                  "printedName": "UInt32",
+                  "usr": "s:s6UInt32V"
+                },
                 {
-                  "kind": "TypeNominal",
-                  "name": "Slice",
-                  "printedName": "Slice<UInt32.Words>",
-                  "usr": "s:s5SliceV",
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "UInt32.Words",
-                      "usr": "s:s6UInt32V5WordsV"
+                      "name": "UInt32",
+                      "printedName": "UInt32",
+                      "usr": "s:s6UInt32V"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt32V5WordsV6_valueABvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt32V5WordsV6_valueABvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s6UInt32V5WordsVyAdBcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56354,19 +58689,18 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s6UInt32V5WordsVyAdBcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:s6UInt32V5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56378,10 +58712,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt32V5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -56389,21 +58719,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt32V5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt32V5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:s6UInt32V5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56415,10 +58747,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt32V5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -56426,21 +58754,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt32V5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt32V5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:s6UInt32V5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56452,10 +58782,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt32V5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -56463,32 +58789,47 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt32V5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt32V5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:s6UInt32V5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "UInt32.Words.Indices",
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Int>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -56496,55 +58837,26 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
+                  ],
                   "declKind": "Accessor",
                   "usr": "s:s6UInt32V5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Indices",
-                      "printedName": "UInt32.Words.Indices",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Range",
-                          "printedName": "Range<Int>",
-                          "usr": "s:Sn",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Int",
-                              "printedName": "Int",
-                              "usr": "s:Si"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt32V5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:s6UInt32V5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56558,19 +58870,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s6UInt32V5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:s6UInt32V5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56584,80 +58895,57 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s6UInt32V5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt32V5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UInt",
                   "printedName": "UInt",
                   "usr": "s:Su"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt32V5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                },
                 {
                   "kind": "TypeNominal",
                   "name": "Int",
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt32V5WordsV8Iteratora",
-              "location": "",
+              ],
+              "declKind": "Subscript",
+              "usr": "s:s6UInt32V5WordsVySuSicip",
               "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<UInt32.Words>",
-                  "usr": "s:s16IndexingIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "UInt32.Words",
-                      "usr": "s:s6UInt32V5WordsV"
-                    }
-                  ]
-                }
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s6UInt32V5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V5wordsAB5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56669,10 +58957,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V5wordsAB5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56680,43 +58964,28 @@
                   "printedName": "UInt32.Words",
                   "usr": "s:s6UInt32V5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V5wordsAB5WordsVvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Magnitude",
-          "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt32V9Magnitudea",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V5wordsAB5WordsVvp",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V19multipliedFullWidth2byAB4high_AB3lowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: UInt32, low: UInt32.Magnitude)",
+              "printedName": "(high: UInt32, low: UInt32)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56725,17 +58994,10 @@
                   "usr": "s:s6UInt32V"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "UInt32.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt32",
-                      "printedName": "UInt32",
-                      "usr": "s:s6UInt32V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt32",
+                  "printedName": "UInt32",
+                  "usr": "s:s6UInt32V"
                 }
               ]
             },
@@ -56745,19 +59007,18 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V19multipliedFullWidth2byAB4high_AB3lowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_AB3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56781,7 +59042,7 @@
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: UInt32, low: UInt32.Magnitude)",
+              "printedName": "(high: UInt32, low: UInt32)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56790,33 +59051,25 @@
                   "usr": "s:s6UInt32V"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "UInt32.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt32",
-                      "printedName": "UInt32",
-                      "usr": "s:s6UInt32V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt32",
+                  "printedName": "UInt32",
+                  "usr": "s:s6UInt32V"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_AB3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V11byteSwappedABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56828,10 +59081,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V11byteSwappedABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56839,43 +59088,84 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V11byteSwappedABvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V11byteSwappedABvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Function",
-          "name": "toIntMax",
-          "printedName": "toIntMax()",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V8toIntMaxs5Int64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Var",
+          "name": "_value",
+          "printedName": "_value",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "BuiltinInteger",
+              "printedName": "Builtin.Int32"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int32"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V6_valueBi32_vg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int32"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V6_valueBi32_vs",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V6_valueBi32_vp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "hasStorage": true
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V6signumAByF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56883,37 +59173,19 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt32V6Stridea",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V6signumAByF",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32V4fromABs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56927,20 +59199,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt32V4fromABs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56953,19 +59221,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56978,16 +59243,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -56999,10 +59266,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57010,23 +59273,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32V20truncatingBitPatternABs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -57036,25 +59298,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1aoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32V20truncatingBitPatternABs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -57064,25 +59330,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1ooiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32V20truncatingBitPatternABSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -57092,25 +59362,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1xoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32V20truncatingBitPatternABSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -57120,23 +59394,317 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V3aggoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V3alloiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1roiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2leoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2geoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1goiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32VyABs7UnicodeO6ScalarVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57150,16 +59718,18 @@
               "printedName": "Unicode.Scalar",
               "usr": "s:s7UnicodeO6ScalarV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt32VyABs7UnicodeO6ScalarVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -57171,10 +59741,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57182,23 +59748,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V25customPlaygroundQuickLooks01_cdE0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57210,10 +59773,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V25customPlaygroundQuickLooks01_cdE0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57221,73 +59780,57 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V25customPlaygroundQuickLooks01_cdE0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V25customPlaygroundQuickLooks01_cdE0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "Int32",
-      "printedName": "Int32",
+      ],
       "declKind": "Struct",
-      "usr": "s:s5Int32V",
-      "location": "",
+      "usr": "s:s6UInt32V",
       "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "Comparable",
-        "SignedInteger",
+        "UnsignedInteger",
         "_ExpressibleByBuiltinIntegerLiteral",
         "BinaryInteger",
         "LosslessStringConvertible",
-        "SignedNumeric",
         "Numeric",
         "CustomStringConvertible",
         "Strideable",
         "ExpressibleByIntegerLiteral",
         "FixedWidthInteger",
-        "Decodable",
         "Encodable",
+        "Decodable",
         "Hashable",
         "Equatable",
         "_HasCustomAnyHashableRepresentation",
         "CustomReflectable",
         "_CustomPlaygroundQuickLookable",
         "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Int32",
+      "printedName": "Int32",
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "IntegerLiteralType",
-          "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int32V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
-            }
-          ]
-        },
-        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32V10bitPatternABs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57301,25 +59844,57 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int32V10bitPatternABs6UInt32V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int32VyABSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
+              "name": "Optional",
+              "printedName": "Optional<Int32>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int32",
+                  "printedName": "Int32",
+                  "usr": "s:s5Int32V"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -57327,85 +59902,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int32V7exactlyABSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Int32?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int32",
-                  "printedName": "Int32",
-                  "usr": "s:s5Int32V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int32VyABSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57413,7 +59951,8 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -57421,19 +59960,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int32V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32VyABs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57447,25 +59985,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int32VyABs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32V7exactlyABSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int32?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int32>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57473,7 +60009,8 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -57481,19 +60018,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int32V7exactlyABSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57520,19 +60244,18 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57559,19 +60282,18 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57598,19 +60320,18 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57637,19 +60358,18 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57676,20 +60396,204 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2reoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2aeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2oeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2xeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V4aggeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V4alleoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s5Int32V8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57701,11 +60605,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57713,21 +60612,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int32V19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57739,10 +60642,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57750,21 +60649,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int32V20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57776,10 +60677,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57787,21 +60684,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int32V15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57813,10 +60712,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57824,88 +60719,71 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:s5Int32V5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int32V5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Var",
+              "name": "_value",
+              "printedName": "_value",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Int>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int32V5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                  "name": "Int32",
+                  "printedName": "Int32",
+                  "usr": "s:s5Int32V"
+                },
                 {
-                  "kind": "TypeNominal",
-                  "name": "Slice",
-                  "printedName": "Slice<Int32.Words>",
-                  "usr": "s:s5SliceV",
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "Int32.Words",
-                      "usr": "s:s5Int32V5WordsV"
+                      "name": "Int32",
+                      "printedName": "Int32",
+                      "usr": "s:s5Int32V"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int32V5WordsV6_valueABvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int32V5WordsV6_valueABvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s5Int32V5WordsVyAdBcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57919,19 +60797,18 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s5Int32V5WordsVyAdBcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:s5Int32V5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57943,10 +60820,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int32V5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -57954,21 +60827,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int32V5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int32V5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:s5Int32V5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57980,10 +60855,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int32V5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -57991,21 +60862,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int32V5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int32V5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:s5Int32V5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58017,10 +60890,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int32V5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -58028,32 +60897,47 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int32V5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int32V5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:s5Int32V5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "Int32.Words.Indices",
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Int>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -58061,55 +60945,26 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
+                  ],
                   "declKind": "Accessor",
                   "usr": "s:s5Int32V5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Indices",
-                      "printedName": "Int32.Words.Indices",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Range",
-                          "printedName": "Range<Int>",
-                          "usr": "s:Sn",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Int",
-                              "printedName": "Int",
-                              "usr": "s:Si"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int32V5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:s5Int32V5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58123,19 +60978,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s5Int32V5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:s5Int32V5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58149,80 +61003,57 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s5Int32V5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int32V5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UInt",
                   "printedName": "UInt",
                   "usr": "s:Su"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int32V5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                },
                 {
                   "kind": "TypeNominal",
                   "name": "Int",
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int32V5WordsV8Iteratora",
-              "location": "",
+              ],
+              "declKind": "Subscript",
+              "usr": "s:s5Int32V5WordsVySuSicip",
               "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<Int32.Words>",
-                  "usr": "s:s16IndexingIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "Int32.Words",
-                      "usr": "s:s5Int32V5WordsV"
-                    }
-                  ]
-                }
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s5Int32V5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:s5Int32V5wordsAB5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58234,10 +61065,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V5wordsAB5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58245,38 +61072,23 @@
                   "printedName": "Int32.Words",
                   "usr": "s:s5Int32V5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V5wordsAB5WordsVvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Magnitude",
-          "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int32V9Magnitudea",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V5wordsAB5WordsVvp",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:s5Int32V9magnitudes6UInt32Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58288,10 +61100,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V9magnitudes6UInt32Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58299,26 +61107,28 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V9magnitudes6UInt32Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V9magnitudes6UInt32Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V19multipliedFullWidth2byAB4high_s6UInt32V3lowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: Int32, low: Int32.Magnitude)",
+              "printedName": "(high: Int32, low: UInt32)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58327,17 +61137,10 @@
                   "usr": "s:s5Int32V"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "Int32.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt32",
-                      "printedName": "UInt32",
-                      "usr": "s:s6UInt32V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt32",
+                  "printedName": "UInt32",
+                  "usr": "s:s6UInt32V"
                 }
               ]
             },
@@ -58347,19 +61150,18 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V19multipliedFullWidth2byAB4high_s6UInt32V3lowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_s6UInt32V3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58383,7 +61185,7 @@
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: Int32, low: Int32.Magnitude)",
+              "printedName": "(high: Int32, low: UInt32)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58392,33 +61194,25 @@
                   "usr": "s:s5Int32V"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "Int32.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt32",
-                      "printedName": "UInt32",
-                      "usr": "s:s6UInt32V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt32",
+                  "printedName": "UInt32",
+                  "usr": "s:s6UInt32V"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_s6UInt32V3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s5Int32V11byteSwappedABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58430,10 +61224,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V11byteSwappedABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58441,43 +61231,84 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V11byteSwappedABvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V11byteSwappedABvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Function",
-          "name": "toUIntMax",
-          "printedName": "toUIntMax()",
-          "declKind": "Func",
-          "usr": "s:s5Int32V9toUIntMaxs6UInt64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Var",
+          "name": "_value",
+          "printedName": "_value",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "BuiltinInteger",
+              "printedName": "Builtin.Int32"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int32"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V6_valueBi32_vg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int32"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V6_valueBi32_vs",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V6_valueBi32_vp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "hasStorage": true
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:s5Int32V6signumAByF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58485,37 +61316,19 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int32V6Stridea",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V6signumAByF",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32V4fromABs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58529,20 +61342,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int32V4fromABs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58555,19 +61364,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58580,16 +61386,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s5Int32V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -58601,10 +61409,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58612,23 +61416,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32V20truncatingBitPatternABs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -58638,25 +61441,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1aoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32V20truncatingBitPatternABs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -58666,25 +61473,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1ooiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32V20truncatingBitPatternABSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -58694,25 +61505,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1xoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32V20truncatingBitPatternABSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -58722,20 +61537,317 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V3aggoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V3alloiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1roiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2leoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2geoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1goiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s5Int32V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -58747,10 +61859,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58758,23 +61866,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:s5Int32V25customPlaygroundQuickLooks01_cdE0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58786,10 +61891,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V25customPlaygroundQuickLooks01_cdE0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58797,73 +61898,58 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V25customPlaygroundQuickLooks01_cdE0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V25customPlaygroundQuickLooks01_cdE0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s5Int32V",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Comparable",
+        "SignedInteger",
+        "_ExpressibleByBuiltinIntegerLiteral",
+        "BinaryInteger",
+        "LosslessStringConvertible",
+        "SignedNumeric",
+        "Numeric",
+        "CustomStringConvertible",
+        "Strideable",
+        "ExpressibleByIntegerLiteral",
+        "FixedWidthInteger",
+        "Encodable",
+        "Decodable",
+        "Hashable",
+        "Equatable",
+        "_HasCustomAnyHashableRepresentation",
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UInt64",
       "printedName": "UInt64",
-      "declKind": "Struct",
-      "usr": "s:s6UInt64V",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Comparable",
-        "UnsignedInteger",
-        "_ExpressibleByBuiltinIntegerLiteral",
-        "BinaryInteger",
-        "LosslessStringConvertible",
-        "Numeric",
-        "CustomStringConvertible",
-        "Strideable",
-        "ExpressibleByIntegerLiteral",
-        "FixedWidthInteger",
-        "Decodable",
-        "Encodable",
-        "Hashable",
-        "Equatable",
-        "_HasCustomAnyHashableRepresentation",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "CVarArg",
-        "_CVarArgAligned"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "IntegerLiteralType",
-          "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt64V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
-        },
-        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt64V10bitPatternABs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58877,25 +61963,57 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt64V10bitPatternABs5Int64V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt64VyABSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "Optional",
+              "printedName": "Optional<UInt64>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt64",
+                  "printedName": "UInt64",
+                  "usr": "s:s6UInt64V"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -58903,85 +62021,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt64V7exactlyABSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UInt64?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt64",
-                  "printedName": "UInt64",
-                  "usr": "s:s6UInt64V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt64VyABSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt64V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58989,7 +62070,8 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -58997,19 +62079,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt64V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt64VyABs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59023,25 +62104,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt64VyABs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt64V7exactlyABSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59049,7 +62128,8 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -59057,19 +62137,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt64V7exactlyABSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59096,19 +62363,18 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59135,19 +62401,18 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59174,19 +62439,18 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59213,19 +62477,18 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59252,20 +62515,204 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2reoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2aeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2oeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2xeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V4aggeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V4alleoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59277,11 +62724,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59289,21 +62731,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59315,10 +62761,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59326,21 +62768,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59352,10 +62796,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59363,21 +62803,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59389,10 +62831,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59400,88 +62838,71 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:s6UInt64V5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt64V5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Var",
+              "name": "_value",
+              "printedName": "_value",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Int>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt64V5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                  "name": "UInt64",
+                  "printedName": "UInt64",
+                  "usr": "s:s6UInt64V"
+                },
                 {
-                  "kind": "TypeNominal",
-                  "name": "Slice",
-                  "printedName": "Slice<UInt64.Words>",
-                  "usr": "s:s5SliceV",
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "UInt64.Words",
-                      "usr": "s:s6UInt64V5WordsV"
+                      "name": "UInt64",
+                      "printedName": "UInt64",
+                      "usr": "s:s6UInt64V"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt64V5WordsV6_valueABvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt64V5WordsV6_valueABvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s6UInt64V5WordsVyAdBcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59495,19 +62916,18 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s6UInt64V5WordsVyAdBcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:s6UInt64V5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59519,10 +62939,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt64V5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -59530,21 +62946,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt64V5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt64V5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:s6UInt64V5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59556,10 +62974,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt64V5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -59567,21 +62981,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt64V5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt64V5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:s6UInt64V5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59593,10 +63009,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt64V5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -59604,32 +63016,47 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt64V5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt64V5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:s6UInt64V5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "UInt64.Words.Indices",
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Int>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -59637,55 +63064,26 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
+                  ],
                   "declKind": "Accessor",
                   "usr": "s:s6UInt64V5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Indices",
-                      "printedName": "UInt64.Words.Indices",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Range",
-                          "printedName": "Range<Int>",
-                          "usr": "s:Sn",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Int",
-                              "printedName": "Int",
-                              "usr": "s:Si"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt64V5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:s6UInt64V5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59699,19 +63097,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s6UInt64V5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:s6UInt64V5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59725,80 +63122,57 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s6UInt64V5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt64V5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UInt",
                   "printedName": "UInt",
                   "usr": "s:Su"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt64V5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                },
                 {
                   "kind": "TypeNominal",
                   "name": "Int",
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt64V5WordsV8Iteratora",
-              "location": "",
+              ],
+              "declKind": "Subscript",
+              "usr": "s:s6UInt64V5WordsVySuSicip",
               "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<UInt64.Words>",
-                  "usr": "s:s16IndexingIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "UInt64.Words",
-                      "usr": "s:s6UInt64V5WordsV"
-                    }
-                  ]
-                }
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s6UInt64V5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V5wordsAB5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59810,10 +63184,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V5wordsAB5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59821,43 +63191,28 @@
                   "printedName": "UInt64.Words",
                   "usr": "s:s6UInt64V5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V5wordsAB5WordsVvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Magnitude",
-          "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt64V9Magnitudea",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V5wordsAB5WordsVvp",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V19multipliedFullWidth2byAB4high_AB3lowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: UInt64, low: UInt64.Magnitude)",
+              "printedName": "(high: UInt64, low: UInt64)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59866,17 +63221,10 @@
                   "usr": "s:s6UInt64V"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "UInt64.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt64",
-                      "printedName": "UInt64",
-                      "usr": "s:s6UInt64V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt64",
+                  "printedName": "UInt64",
+                  "usr": "s:s6UInt64V"
                 }
               ]
             },
@@ -59886,19 +63234,18 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V19multipliedFullWidth2byAB4high_AB3lowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_AB3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59922,7 +63269,7 @@
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: UInt64, low: UInt64.Magnitude)",
+              "printedName": "(high: UInt64, low: UInt64)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59931,33 +63278,25 @@
                   "usr": "s:s6UInt64V"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "UInt64.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt64",
-                      "printedName": "UInt64",
-                      "usr": "s:s6UInt64V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt64",
+                  "printedName": "UInt64",
+                  "usr": "s:s6UInt64V"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_AB3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V11byteSwappedABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59969,10 +63308,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V11byteSwappedABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59980,43 +63315,84 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V11byteSwappedABvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V11byteSwappedABvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Function",
-          "name": "toIntMax",
-          "printedName": "toIntMax()",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V8toIntMaxs5Int64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Var",
+          "name": "_value",
+          "printedName": "_value",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "BuiltinInteger",
+              "printedName": "Builtin.Int64"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int64"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V6_valueBi64_vg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int64"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V6_valueBi64_vs",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V6_valueBi64_vp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "hasStorage": true
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V6signumAByF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60024,37 +63400,19 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt64V6Stridea",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V6signumAByF",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt64V4fromABs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60068,20 +63426,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt64V4fromABs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60094,19 +63448,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60119,16 +63470,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -60140,10 +63493,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60151,21 +63500,438 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1aoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1ooiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1xoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V3aggoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V3alloiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1roiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2leoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2geoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1goiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt64VyABs7UnicodeO6ScalarVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60179,16 +63945,18 @@
               "printedName": "Unicode.Scalar",
               "usr": "s:s7UnicodeO6ScalarV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt64VyABs7UnicodeO6ScalarVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -60200,10 +63968,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60211,23 +63975,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V25customPlaygroundQuickLooks01_cdE0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60239,10 +64000,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V25customPlaygroundQuickLooks01_cdE0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60250,34 +64007,40 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V25customPlaygroundQuickLooks01_cdE0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V25customPlaygroundQuickLooks01_cdE0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "Int64",
-      "printedName": "Int64",
+      ],
       "declKind": "Struct",
-      "usr": "s:s5Int64V",
-      "location": "",
+      "usr": "s:s6UInt64V",
       "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "Comparable",
-        "SignedInteger",
+        "UnsignedInteger",
         "_ExpressibleByBuiltinIntegerLiteral",
         "BinaryInteger",
         "LosslessStringConvertible",
-        "SignedNumeric",
         "Numeric",
         "CustomStringConvertible",
         "Strideable",
         "ExpressibleByIntegerLiteral",
         "FixedWidthInteger",
-        "Decodable",
         "Encodable",
+        "Decodable",
         "Hashable",
         "Equatable",
         "_HasCustomAnyHashableRepresentation",
@@ -60285,39 +64048,17 @@
         "_CustomPlaygroundQuickLookable",
         "CVarArg",
         "_CVarArgAligned"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Int64",
+      "printedName": "Int64",
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "IntegerLiteralType",
-          "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int64V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int64V10bitPatternABs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60331,25 +64072,57 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int64V10bitPatternABs6UInt64V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int64VyABSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "Optional",
+              "printedName": "Optional<Int64>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int64",
+                  "printedName": "Int64",
+                  "usr": "s:s5Int64V"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -60357,85 +64130,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int64V7exactlyABSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Int64?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int64",
-                  "printedName": "Int64",
-                  "usr": "s:s5Int64V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int64VyABSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int64V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60443,7 +64179,8 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -60451,19 +64188,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int64V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int64VyABs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60477,25 +64213,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int64VyABs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int64V7exactlyABSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int64?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int64>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60503,7 +64237,8 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -60511,19 +64246,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int64V7exactlyABSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60550,19 +64472,18 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60589,19 +64510,18 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60628,19 +64548,18 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60667,19 +64586,18 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60706,20 +64624,204 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2reoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2aeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2oeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2xeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V4aggeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V4alleoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s5Int64V8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60731,11 +64833,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60743,21 +64840,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int64V19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60769,10 +64870,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60780,21 +64877,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int64V20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60806,10 +64905,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60817,21 +64912,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int64V15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60843,10 +64940,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60854,88 +64947,71 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:s5Int64V5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int64V5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Var",
+              "name": "_value",
+              "printedName": "_value",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Int>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int64V5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                  "name": "Int64",
+                  "printedName": "Int64",
+                  "usr": "s:s5Int64V"
+                },
                 {
-                  "kind": "TypeNominal",
-                  "name": "Slice",
-                  "printedName": "Slice<Int64.Words>",
-                  "usr": "s:s5SliceV",
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "Int64.Words",
-                      "usr": "s:s5Int64V5WordsV"
+                      "name": "Int64",
+                      "printedName": "Int64",
+                      "usr": "s:s5Int64V"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int64V5WordsV6_valueABvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int64V5WordsV6_valueABvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s5Int64V5WordsVyAdBcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60949,19 +65025,18 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s5Int64V5WordsVyAdBcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:s5Int64V5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60973,10 +65048,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int64V5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -60984,21 +65055,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int64V5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int64V5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:s5Int64V5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61010,10 +65083,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int64V5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -61021,21 +65090,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int64V5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int64V5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:s5Int64V5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61047,10 +65118,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int64V5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -61058,32 +65125,47 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int64V5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int64V5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:s5Int64V5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "Int64.Words.Indices",
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Int>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -61091,55 +65173,26 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
+                  ],
                   "declKind": "Accessor",
                   "usr": "s:s5Int64V5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Indices",
-                      "printedName": "Int64.Words.Indices",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Range",
-                          "printedName": "Range<Int>",
-                          "usr": "s:Sn",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Int",
-                              "printedName": "Int",
-                              "usr": "s:Si"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int64V5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:s5Int64V5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61153,19 +65206,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s5Int64V5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:s5Int64V5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61179,80 +65231,57 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s5Int64V5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int64V5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UInt",
                   "printedName": "UInt",
                   "usr": "s:Su"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int64V5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                },
                 {
                   "kind": "TypeNominal",
                   "name": "Int",
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int64V5WordsV8Iteratora",
-              "location": "",
+              ],
+              "declKind": "Subscript",
+              "usr": "s:s5Int64V5WordsVySuSicip",
               "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<Int64.Words>",
-                  "usr": "s:s16IndexingIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "Int64.Words",
-                      "usr": "s:s5Int64V5WordsV"
-                    }
-                  ]
-                }
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s5Int64V5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:s5Int64V5wordsAB5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61264,10 +65293,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V5wordsAB5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61275,38 +65300,23 @@
                   "printedName": "Int64.Words",
                   "usr": "s:s5Int64V5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V5wordsAB5WordsVvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Magnitude",
-          "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int64V9Magnitudea",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V5wordsAB5WordsVvp",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:s5Int64V9magnitudes6UInt64Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61318,10 +65328,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V9magnitudes6UInt64Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61329,26 +65335,28 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V9magnitudes6UInt64Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V9magnitudes6UInt64Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V19multipliedFullWidth2byAB4high_s6UInt64V3lowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: Int64, low: Int64.Magnitude)",
+              "printedName": "(high: Int64, low: UInt64)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61357,17 +65365,10 @@
                   "usr": "s:s5Int64V"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "Int64.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt64",
-                      "printedName": "UInt64",
-                      "usr": "s:s6UInt64V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt64",
+                  "printedName": "UInt64",
+                  "usr": "s:s6UInt64V"
                 }
               ]
             },
@@ -61377,19 +65378,18 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V19multipliedFullWidth2byAB4high_s6UInt64V3lowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_s6UInt64V3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61413,7 +65413,7 @@
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: Int64, low: Int64.Magnitude)",
+              "printedName": "(high: Int64, low: UInt64)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61422,33 +65422,25 @@
                   "usr": "s:s5Int64V"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "Int64.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt64",
-                      "printedName": "UInt64",
-                      "usr": "s:s6UInt64V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt64",
+                  "printedName": "UInt64",
+                  "usr": "s:s6UInt64V"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_s6UInt64V3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s5Int64V11byteSwappedABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61460,10 +65452,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V11byteSwappedABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61471,43 +65459,84 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V11byteSwappedABvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V11byteSwappedABvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Function",
-          "name": "toUIntMax",
-          "printedName": "toUIntMax()",
-          "declKind": "Func",
-          "usr": "s:s5Int64V9toUIntMaxs6UInt64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Var",
+          "name": "_value",
+          "printedName": "_value",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "BuiltinInteger",
+              "printedName": "Builtin.Int64"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int64"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V6_valueBi64_vg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int64"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V6_valueBi64_vs",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V6_valueBi64_vp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "hasStorage": true
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:s5Int64V6signumAByF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61515,37 +65544,19 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int64V6Stridea",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V6signumAByF",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int64V4fromABs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61559,20 +65570,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int64V4fromABs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61585,19 +65592,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61610,16 +65614,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s5Int64V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -61631,10 +65637,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61642,18 +65644,438 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1aoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1ooiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1xoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V3aggoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V3alloiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1roiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2leoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2geoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1goiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s5Int64V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -61665,10 +66087,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61676,23 +66094,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:s5Int64V25customPlaygroundQuickLooks01_cdE0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61704,10 +66119,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V25customPlaygroundQuickLooks01_cdE0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61715,72 +66126,59 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V25customPlaygroundQuickLooks01_cdE0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V25customPlaygroundQuickLooks01_cdE0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s5Int64V",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Comparable",
+        "SignedInteger",
+        "_ExpressibleByBuiltinIntegerLiteral",
+        "BinaryInteger",
+        "LosslessStringConvertible",
+        "SignedNumeric",
+        "Numeric",
+        "CustomStringConvertible",
+        "Strideable",
+        "ExpressibleByIntegerLiteral",
+        "FixedWidthInteger",
+        "Encodable",
+        "Decodable",
+        "Hashable",
+        "Equatable",
+        "_HasCustomAnyHashableRepresentation",
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "CVarArg",
+        "_CVarArgAligned"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UInt",
       "printedName": "UInt",
-      "declKind": "Struct",
-      "usr": "s:Su",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Comparable",
-        "UnsignedInteger",
-        "_ExpressibleByBuiltinIntegerLiteral",
-        "BinaryInteger",
-        "LosslessStringConvertible",
-        "Numeric",
-        "CustomStringConvertible",
-        "Strideable",
-        "ExpressibleByIntegerLiteral",
-        "FixedWidthInteger",
-        "Decodable",
-        "Encodable",
-        "Hashable",
-        "Equatable",
-        "_HasCustomAnyHashableRepresentation",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "IntegerLiteralType",
-          "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Su18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
-          ]
-        },
-        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Su10bitPatternSuSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61794,25 +66192,57 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Su10bitPatternSuSi_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SuySuSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
+              "name": "Optional",
+              "printedName": "Optional<UInt>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -61820,85 +66250,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:Su7exactlySuSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UInt?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt",
-                  "printedName": "UInt",
-                  "usr": "s:Su"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SuySuSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Su7exactlySuSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61906,7 +66299,8 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -61914,19 +66308,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Su7exactlySuSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SuySus7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61940,25 +66333,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SuySus7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Su7exactlySuSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UInt?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UInt>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61966,7 +66357,8 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -61974,19 +66366,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Su7exactlySuSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2eeoiySbSu_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1loiySbSu_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2peoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2seoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2meoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2deoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:Su24dividedReportingOverflow2bySu12partialValue_Sb8overflowtSu_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62013,19 +66592,18 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su24dividedReportingOverflow2bySu12partialValue_Sb8overflowtSu_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:Su26remainderReportingOverflow10dividingBySu12partialValue_Sb8overflowtSu_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62052,19 +66630,18 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su26remainderReportingOverflow10dividingBySu12partialValue_Sb8overflowtSu_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:Su23addingReportingOverflowySu12partialValue_Sb8overflowtSuF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62091,19 +66668,18 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su23addingReportingOverflowySu12partialValue_Sb8overflowtSuF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:Su28subtractingReportingOverflowySu12partialValue_Sb8overflowtSuF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62130,19 +66706,18 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su28subtractingReportingOverflowySu12partialValue_Sb8overflowtSuF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:Su27multipliedReportingOverflow2bySu12partialValue_Sb8overflowtSu_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62169,20 +66744,204 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su27multipliedReportingOverflow2bySu12partialValue_Sb8overflowtSu_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2reoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2aeoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2oeoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2xeoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su4aggeoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su4alleoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:Su8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62194,11 +66953,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62206,21 +66960,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Su8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:Su19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62232,10 +66990,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62243,21 +66997,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Su19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:Su20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62269,10 +67025,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62280,21 +67032,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Su20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:Su15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62306,10 +67060,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62317,88 +67067,71 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Su15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:Su5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:Su5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Var",
+              "name": "_value",
+              "printedName": "_value",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Int>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:Su5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
+                },
                 {
-                  "kind": "TypeNominal",
-                  "name": "Slice",
-                  "printedName": "Slice<UInt.Words>",
-                  "usr": "s:s5SliceV",
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "UInt.Words",
-                      "usr": "s:Su5WordsV"
+                      "name": "UInt",
+                      "printedName": "UInt",
+                      "usr": "s:Su"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Su5WordsV6_valueSuvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:Su5WordsV6_valueSuvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:Su5WordsVyABSucfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62412,19 +67145,18 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:Su5WordsVyABSucfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:Su5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62436,10 +67168,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Su5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -62447,21 +67175,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Su5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Su5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:Su5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62473,10 +67203,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Su5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -62484,21 +67210,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Su5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Su5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:Su5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62510,10 +67238,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Su5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -62521,32 +67245,47 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Su5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Su5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:Su5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "UInt.Words.Indices",
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Int>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -62554,55 +67293,26 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
+                  ],
                   "declKind": "Accessor",
                   "usr": "s:Su5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Indices",
-                      "printedName": "UInt.Words.Indices",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Range",
-                          "printedName": "Range<Int>",
-                          "usr": "s:Sn",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Int",
-                              "printedName": "Int",
-                              "usr": "s:Si"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Su5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:Su5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62616,19 +67326,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Su5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:Su5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62642,80 +67351,57 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Su5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:Su5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UInt",
                   "printedName": "UInt",
                   "usr": "s:Su"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:Su5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                },
                 {
                   "kind": "TypeNominal",
                   "name": "Int",
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:Su5WordsV8Iteratora",
-              "location": "",
+              ],
+              "declKind": "Subscript",
+              "usr": "s:Su5WordsVySuSicip",
               "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<UInt.Words>",
-                  "usr": "s:s16IndexingIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "UInt.Words",
-                      "usr": "s:Su5WordsV"
-                    }
-                  ]
-                }
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:Su5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:Su5wordsSu5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62727,10 +67413,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su5wordsSu5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62738,43 +67420,28 @@
                   "printedName": "UInt.Words",
                   "usr": "s:Su5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su5wordsSu5WordsVvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Magnitude",
-          "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:Su9Magnitudea",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:Su5wordsSu5WordsVvp",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:Su19multipliedFullWidth2bySu4high_Su3lowtSu_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: UInt, low: UInt.Magnitude)",
+              "printedName": "(high: UInt, low: UInt)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62783,17 +67450,10 @@
                   "usr": "s:Su"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "UInt.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt",
-                      "printedName": "UInt",
-                      "usr": "s:Su"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
                 }
               ]
             },
@@ -62803,19 +67463,18 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su19multipliedFullWidth2bySu4high_Su3lowtSu_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:Su17dividingFullWidthySu8quotient_Su9remaindertSu4high_Su3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62839,7 +67498,7 @@
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: UInt, low: UInt.Magnitude)",
+              "printedName": "(high: UInt, low: UInt)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62848,33 +67507,25 @@
                   "usr": "s:Su"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "UInt.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt",
-                      "printedName": "UInt",
-                      "usr": "s:Su"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su17dividingFullWidthySu8quotient_Su9remaindertSu4high_Su3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:Su11byteSwappedSuvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62886,10 +67537,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su11byteSwappedSuvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62897,43 +67544,84 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su11byteSwappedSuvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Su11byteSwappedSuvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Function",
-          "name": "toIntMax",
-          "printedName": "toIntMax()",
-          "declKind": "Func",
-          "usr": "s:Su8toIntMaxs5Int64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Var",
+          "name": "_value",
+          "printedName": "_value",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "BuiltinInteger",
+              "printedName": "Builtin.Int64"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int64"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su6_valueBi64_vg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int64"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su6_valueBi64_vs",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Su6_valueBi64_vp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "hasStorage": true
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:Su6signumSuyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62941,37 +67629,19 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:Su6Stridea",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:Su6signumSuyF",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:Su4fromSus7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62985,20 +67655,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Su4fromSus7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:Su6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63011,19 +67677,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Su6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Su10bitPatternSus13OpaquePointerVSg_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63034,8 +67697,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "OpaquePointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<OpaquePointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63043,21 +67705,21 @@
                   "printedName": "OpaquePointer",
                   "usr": "s:s13OpaquePointerV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Su10bitPatternSus13OpaquePointerVSg_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:Su4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63070,16 +67732,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Su9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -63091,10 +67755,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63102,23 +67762,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Su9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Su20truncatingBitPatternSus6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -63128,25 +67787,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1aoiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Su20truncatingBitPatternSus5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -63156,20 +67819,381 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1ooiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1xoiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su3aggoiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su3alloiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1doiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1roiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1poiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1soiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1moiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2leoiySbSu_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2geoiySbSu_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1goiySbSu_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Su12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -63181,10 +68205,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63192,23 +68212,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su12customMirrors0B0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Su12customMirrors0B0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:Su25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63220,10 +68237,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63231,21 +68244,24 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Su25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Su10bitPatternSuSO_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63259,20 +68275,18 @@
               "printedName": "ObjectIdentifier",
               "usr": "s:SO"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Su10bitPatternSuSO_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Su10bitPatternSuxSg_tcs8_PointerRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<P where P : _Pointer>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63283,82 +68297,62 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "P?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "P"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Su10bitPatternSuxSg_tcs8_PointerRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _Pointer>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:Su",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Comparable",
+        "UnsignedInteger",
+        "_ExpressibleByBuiltinIntegerLiteral",
+        "BinaryInteger",
+        "LosslessStringConvertible",
+        "Numeric",
+        "CustomStringConvertible",
+        "Strideable",
+        "ExpressibleByIntegerLiteral",
+        "FixedWidthInteger",
+        "Encodable",
+        "Decodable",
+        "Hashable",
+        "Equatable",
+        "_HasCustomAnyHashableRepresentation",
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Int",
       "printedName": "Int",
-      "declKind": "Struct",
-      "usr": "s:Si",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Comparable",
-        "SignedInteger",
-        "_ExpressibleByBuiltinIntegerLiteral",
-        "BinaryInteger",
-        "LosslessStringConvertible",
-        "SignedNumeric",
-        "Numeric",
-        "CustomStringConvertible",
-        "Strideable",
-        "ExpressibleByIntegerLiteral",
-        "FixedWidthInteger",
-        "Decodable",
-        "Encodable",
-        "Hashable",
-        "Equatable",
-        "_HasCustomAnyHashableRepresentation",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "MirrorPath",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "IntegerLiteralType",
-          "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Si18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Si10bitPatternSiSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63372,25 +68366,57 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Si10bitPatternSiSu_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SiySiSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "Optional",
+              "printedName": "Optional<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -63398,85 +68424,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:Si7exactlySiSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SiySiSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Si7exactlySiSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63484,7 +68473,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -63492,19 +68482,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Si7exactlySiSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SiySis7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63518,25 +68507,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SiySis7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Si7exactlySiSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Int>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63544,7 +68531,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -63552,19 +68540,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Si7exactlySiSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2eeoiySbSi_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1loiySbSi_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2peoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2seoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2meoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2deoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:Si24dividedReportingOverflow2bySi12partialValue_Sb8overflowtSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63591,19 +68766,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si24dividedReportingOverflow2bySi12partialValue_Sb8overflowtSi_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:Si26remainderReportingOverflow10dividingBySi12partialValue_Sb8overflowtSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63630,19 +68804,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si26remainderReportingOverflow10dividingBySi12partialValue_Sb8overflowtSi_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:Si23addingReportingOverflowySi12partialValue_Sb8overflowtSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63669,19 +68842,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si23addingReportingOverflowySi12partialValue_Sb8overflowtSiF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:Si28subtractingReportingOverflowySi12partialValue_Sb8overflowtSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63708,19 +68880,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si28subtractingReportingOverflowySi12partialValue_Sb8overflowtSiF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:Si27multipliedReportingOverflow2bySi12partialValue_Sb8overflowtSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63747,20 +68918,204 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si27multipliedReportingOverflow2bySi12partialValue_Sb8overflowtSi_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2reoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2aeoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2oeoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2xeoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si4aggeoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si4alleoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:Si8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63772,11 +69127,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63784,21 +69134,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Si8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:Si19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63810,10 +69164,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63821,21 +69171,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Si19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:Si20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63847,10 +69199,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63858,21 +69206,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Si20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:Si15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63884,10 +69234,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63895,41 +69241,39 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Si15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:Si5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:Si5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Var",
+              "name": "_value",
+              "printedName": "_value",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Int>",
-                  "usr": "s:Sn",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -63937,46 +69281,31 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Si5WordsV6_valueSivg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:Si5WordsV11SubSequencea",
-              "location": "",
+              ],
+              "declKind": "Var",
+              "usr": "s:Si5WordsV6_valueSivp",
               "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Slice",
-                  "printedName": "Slice<Int.Words>",
-                  "usr": "s:s5SliceV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "Int.Words",
-                      "usr": "s:Si5WordsV"
-                    }
-                  ]
-                }
-              ]
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:Si5WordsVyABSicfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63990,19 +69319,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:Si5WordsVyABSicfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:Si5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64014,10 +69342,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Si5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -64025,21 +69349,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Si5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Si5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:Si5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64051,10 +69377,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Si5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -64062,21 +69384,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Si5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Si5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:Si5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64088,10 +69412,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Si5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -64099,32 +69419,47 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Si5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Si5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:Si5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "Int.Words.Indices",
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Int>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -64132,55 +69467,26 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
+                  ],
                   "declKind": "Accessor",
                   "usr": "s:Si5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Indices",
-                      "printedName": "Int.Words.Indices",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Range",
-                          "printedName": "Range<Int>",
-                          "usr": "s:Sn",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Int",
-                              "printedName": "Int",
-                              "usr": "s:Si"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Si5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:Si5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64194,19 +69500,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Si5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:Si5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64220,80 +69525,57 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Si5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:Si5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UInt",
                   "printedName": "UInt",
                   "usr": "s:Su"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:Si5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
+                },
                 {
                   "kind": "TypeNominal",
                   "name": "Int",
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:Si5WordsV8Iteratora",
-              "location": "",
+              ],
+              "declKind": "Subscript",
+              "usr": "s:Si5WordsVySuSicip",
               "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<Int.Words>",
-                  "usr": "s:s16IndexingIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Words",
-                      "printedName": "Int.Words",
-                      "usr": "s:Si5WordsV"
-                    }
-                  ]
-                }
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:Si5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:Si5wordsSi5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64305,10 +69587,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si5wordsSi5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64316,38 +69594,23 @@
                   "printedName": "Int.Words",
                   "usr": "s:Si5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si5wordsSi5WordsVvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Magnitude",
-          "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:Si9Magnitudea",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:Si5wordsSi5WordsVvp",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:Si9magnitudeSuvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64359,10 +69622,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si9magnitudeSuvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64370,26 +69629,28 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si9magnitudeSuvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Si9magnitudeSuvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:Si19multipliedFullWidth2bySi4high_Su3lowtSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: Int, low: Int.Magnitude)",
+              "printedName": "(high: Int, low: UInt)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64398,17 +69659,10 @@
                   "usr": "s:Si"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "Int.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt",
-                      "printedName": "UInt",
-                      "usr": "s:Su"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
                 }
               ]
             },
@@ -64418,19 +69672,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si19multipliedFullWidth2bySi4high_Su3lowtSi_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:Si17dividingFullWidthySi8quotient_Si9remaindertSi4high_Su3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64454,7 +69707,7 @@
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(high: Int, low: Int.Magnitude)",
+              "printedName": "(high: Int, low: UInt)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64463,33 +69716,25 @@
                   "usr": "s:Si"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Magnitude",
-                  "printedName": "Int.Magnitude",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt",
-                      "printedName": "UInt",
-                      "usr": "s:Su"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si17dividingFullWidthySi8quotient_Si9remaindertSi4high_Su3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:Si11byteSwappedSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64501,10 +69746,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si11byteSwappedSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64512,81 +69753,104 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si11byteSwappedSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Si11byteSwappedSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Function",
-          "name": "toUIntMax",
-          "printedName": "toUIntMax()",
-          "declKind": "Func",
-          "usr": "s:Si9toUIntMaxs6UInt64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Var",
+          "name": "_value",
+          "printedName": "_value",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "BuiltinInteger",
+              "printedName": "Builtin.Int64"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int64"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si6_valueBi64_vg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int64"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si6_valueBi64_vs",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Si6_valueBi64_vp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "hasStorage": true
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:Si6signumSiyF",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Inline",
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:Si6Stridea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:Si4fromSis7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64600,20 +69864,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Si4fromSis7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:Si6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64626,19 +69886,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Si6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Si10bitPatternSis13OpaquePointerVSg_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64649,8 +69906,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "OpaquePointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<OpaquePointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64658,73 +69914,21 @@
                   "printedName": "OpaquePointer",
                   "usr": "s:s13OpaquePointerV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(to:)",
-          "declKind": "Func",
-          "usr": "s:Si8distance2toS2i_tF",
-          "location": "",
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Si10bitPatternSis13OpaquePointerVSg_tcfc",
           "moduleName": "Swift",
           "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "advanced",
-          "printedName": "advanced(by:)",
-          "declKind": "Func",
-          "usr": "s:Si8advanced2byS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:Si4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64737,16 +69941,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Si9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -64758,10 +69964,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64769,23 +69971,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Si9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Si20truncatingBitPatternSis6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -64795,25 +69996,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1aoiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Si20truncatingBitPatternSis5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -64823,20 +70028,431 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1ooiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1xoiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si3aggoiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si3alloiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1doiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1roiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1poiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1soiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1moiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2leoiySbSi_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2geoiySbSi_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1goiySbSi_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si8distance2toS2i_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "advanced",
+          "printedName": "advanced(by:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si8advanced2byS2i_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Si12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -64848,10 +70464,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64859,23 +70471,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si12customMirrors0B0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Si12customMirrors0B0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:Si25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64887,10 +70496,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64898,21 +70503,24 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Si25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Si10bitPatternSiSO_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64926,20 +70534,18 @@
               "printedName": "ObjectIdentifier",
               "usr": "s:SO"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Si10bitPatternSiSO_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Si10bitPatternSixSg_tcs8_PointerRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<P where P : _Pointer>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64950,293 +70556,608 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "P?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "P"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Si10bitPatternSixSg_tcs8_PointerRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _Pointer>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
-      ]
-    },
-    {
-      "kind": "Function",
-      "name": "numericCast",
-      "printedName": "numericCast(_:)",
-      "declKind": "Func",
-      "usr": "s:s11numericCastyq_xSzRzSzR_r0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, U where T : BinaryInteger, U : BinaryInteger>",
-      "declAttributes": [
-        "Transparent"
       ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "U"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        }
+      "declKind": "Struct",
+      "usr": "s:Si",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Comparable",
+        "SignedInteger",
+        "_ExpressibleByBuiltinIntegerLiteral",
+        "BinaryInteger",
+        "LosslessStringConvertible",
+        "SignedNumeric",
+        "Numeric",
+        "CustomStringConvertible",
+        "Strideable",
+        "ExpressibleByIntegerLiteral",
+        "FixedWidthInteger",
+        "Encodable",
+        "Decodable",
+        "Hashable",
+        "Equatable",
+        "_HasCustomAnyHashableRepresentation",
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "MirrorPath",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "JoinedSequence",
       "printedName": "JoinedSequence",
-      "declKind": "Struct",
-      "usr": "s:s14JoinedSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-      "conformingProtocols": [
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s14JoinedSequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
+          "kind": "Var",
+          "name": "_base",
+          "printedName": "_base",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element.Element"
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14JoinedSequenceV5_basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s14JoinedSequenceV5_basexvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_separator",
+          "printedName": "_separator",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ContiguousArray",
+              "printedName": "ContiguousArray<τ_0_0.Element.Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element.Element"
+                }
+              ],
+              "usr": "s:s15ContiguousArrayV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ContiguousArray",
+                  "printedName": "ContiguousArray<τ_0_0.Element.Element>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element.Element"
+                    }
+                  ],
+                  "usr": "s:s15ContiguousArrayV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14JoinedSequenceV10_separators15ContiguousArrayVy7Element_AFQZGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14JoinedSequenceV10_separators15ContiguousArrayVy7Element_AFQZGvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "hasStorage": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(base:separator:)",
-          "declKind": "Constructor",
-          "usr": "s:s14JoinedSequenceV4base9separatorAByxGx_qd__tcSTRd__7Element_AFQZAFRtd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Separator where Base : Sequence, Separator : Sequence, Base.Element : Sequence, Separator.Element == Base.Element.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "JoinedSequence",
-              "printedName": "JoinedSequence<Base>",
-              "usr": "s:s14JoinedSequenceV",
+              "printedName": "JoinedSequence<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Base"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s14JoinedSequenceV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Base"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Separator"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s14JoinedSequenceV4base9separatorAByxGx_qd__tcSTRd__7Element_AFQZAFRtd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Sequence, τ_1_0 : Sequence, τ_0_0.Element : Sequence, τ_1_0.Element == τ_0_0.Element.Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s14JoinedSequenceV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-          "conformingProtocols": [
-            "IteratorProtocol"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "Constructor",
-              "name": "init",
-              "printedName": "init(base:separator:)",
-              "declKind": "Constructor",
-              "usr": "s:s14JoinedSequenceV8IteratorV4base9separatorADyx_GACQz_qd__tcSTRd__7Element_AIQZAIRtd__lufc",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Separator where Base : Sequence, Separator : Sequence, Base.Element : Sequence, Separator.Element == Base.Element.Element>",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "JoinedSequence<Base>.Iterator",
-                  "usr": "s:s14JoinedSequenceV8IteratorV"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Iterator"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Separator"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s14JoinedSequenceV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
+              "kind": "Var",
+              "name": "_base",
+              "printedName": "_base",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Base.Element.Element"
+                  "printedName": "τ_0_0.Iterator"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Iterator"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s14JoinedSequenceV8IteratorV5_baseACQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s14JoinedSequenceV8IteratorV5_baseACQzvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
             },
             {
-              "kind": "Function",
-              "name": "next",
-              "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s14JoinedSequenceV8IteratorV4next7Element_AFQZSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
+              "kind": "Var",
+              "name": "_inner",
+              "printedName": "_inner",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "JoinedSequence<Base>.Iterator.Element?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<τ_0_0.Element.Iterator>",
                   "children": [
                     {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "JoinedSequence<Base>.Iterator.Element",
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element.Iterator"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<τ_0_0.Element.Iterator>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "DependentMember",
+                          "printedName": "τ_0_0.Element.Iterator"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s14JoinedSequenceV8IteratorV6_inner7Element_ACQZSgvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s14JoinedSequenceV8IteratorV6_inner7Element_ACQZSgvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "HasInitialValue",
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 1,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_separatorData",
+              "printedName": "_separatorData",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ContiguousArray",
+                  "printedName": "ContiguousArray<τ_0_0.Element.Element>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element.Element"
+                    }
+                  ],
+                  "usr": "s:s15ContiguousArrayV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "ContiguousArray",
+                      "printedName": "ContiguousArray<τ_0_0.Element.Element>",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "DependentMember",
                           "printedName": "τ_0_0.Element.Element"
                         }
-                      ]
+                      ],
+                      "usr": "s:s15ContiguousArrayV"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s14JoinedSequenceV8IteratorV14_separatorDatas15ContiguousArrayVy7Element_AHQZGvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s14JoinedSequenceV8IteratorV14_separatorDatas15ContiguousArrayVy7Element_AHQZGvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 2,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_separator",
+              "printedName": "_separator",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<IndexingIterator<ContiguousArray<τ_0_0.Element.Element>>>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "IndexingIterator",
+                      "printedName": "IndexingIterator<ContiguousArray<τ_0_0.Element.Element>>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "ContiguousArray",
+                          "printedName": "ContiguousArray<τ_0_0.Element.Element>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "DependentMember",
+                              "printedName": "τ_0_0.Element.Element"
+                            }
+                          ],
+                          "usr": "s:s15ContiguousArrayV"
+                        }
+                      ],
+                      "usr": "s:s16IndexingIteratorV"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<IndexingIterator<ContiguousArray<τ_0_0.Element.Element>>>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "IndexingIterator",
+                          "printedName": "IndexingIterator<ContiguousArray<τ_0_0.Element.Element>>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "ContiguousArray",
+                              "printedName": "ContiguousArray<τ_0_0.Element.Element>",
+                              "children": [
+                                {
+                                  "kind": "TypeNominal",
+                                  "name": "DependentMember",
+                                  "printedName": "τ_0_0.Element.Element"
+                                }
+                              ],
+                              "usr": "s:s15ContiguousArrayV"
+                            }
+                          ],
+                          "usr": "s:s16IndexingIteratorV"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s14JoinedSequenceV8IteratorV10_separators08IndexingC0Vys15ContiguousArrayVy7Element_AJQZGGSgvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s14JoinedSequenceV8IteratorV10_separators08IndexingC0Vys15ContiguousArrayVy7Element_AJQZGGSgvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "HasInitialValue",
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 3,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_state",
+              "printedName": "_state",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "JoinIteratorState",
+                  "printedName": "JoinedSequence<τ_0_0>.Iterator.JoinIteratorState",
+                  "usr": "s:s14JoinedSequenceV8IteratorV04JoinC5StateO"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "JoinIteratorState",
+                      "printedName": "JoinedSequence<τ_0_0>.Iterator.JoinIteratorState",
+                      "usr": "s:s14JoinedSequenceV8IteratorV04JoinC5StateO"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s14JoinedSequenceV8IteratorV6_stateAD04JoinC5StateOyx__Gvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s14JoinedSequenceV8IteratorV6_stateAD04JoinC5StateOyx__Gvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "HasInitialValue",
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 4,
+              "hasStorage": true
+            },
+            {
+              "kind": "Constructor",
+              "name": "init",
+              "printedName": "init(base:separator:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Iterator",
+                  "printedName": "JoinedSequence<τ_0_0>.Iterator",
+                  "usr": "s:s14JoinedSequenceV8IteratorV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Iterator"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s14JoinedSequenceV8IteratorV4base9separatorADyx_GACQz_qd__tcSTRd__7Element_AIQZAIRtd__lufc",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Sequence, τ_1_0 : Sequence, τ_0_0.Element : Sequence, τ_1_0.Element == τ_0_0.Element.Element>",
+              "declAttributes": [
+                "Inlinable"
               ]
+            },
+            {
+              "kind": "Function",
+              "name": "next",
+              "printedName": "next()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_0.Element.Element>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element.Element"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s14JoinedSequenceV8IteratorV4next7Element_AFQZSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s14JoinedSequenceV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s14JoinedSequenceV12makeIteratorAB0D0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Iterator",
-              "printedName": "JoinedSequence<Base>.Iterator",
+              "printedName": "JoinedSequence<τ_0_0>.Iterator",
               "usr": "s:s14JoinedSequenceV8IteratorV"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s14JoinedSequenceV03SubB0a",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s14JoinedSequenceV12makeIteratorAB0D0Vyx_GyF",
           "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnySequence",
-              "printedName": "AnySequence<Base.Element.Element>",
-              "usr": "s:s11AnySequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Element.Element"
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s14JoinedSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AnyKeyPath",
       "printedName": "AnyKeyPath",
-      "declKind": "Class",
-      "usr": "s:s10AnyKeyPathC",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Hashable",
-        "_AppendKeyPath",
-        "Equatable"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "rootType",
           "printedName": "rootType",
-          "declKind": "Var",
-          "usr": "s:s10AnyKeyPathC8rootTypeypXpvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Final",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -65254,14 +71175,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10AnyKeyPathC8rootTypeypXpvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Final"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65275,23 +71188,29 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10AnyKeyPathC8rootTypeypXpvgZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Final"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10AnyKeyPathC8rootTypeypXpvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Final",
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "valueType",
           "printedName": "valueType",
-          "declKind": "Var",
-          "usr": "s:s10AnyKeyPathC9valueTypeypXpvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Final",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -65309,14 +71228,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10AnyKeyPathC9valueTypeypXpvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Final"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65330,21 +71241,29 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10AnyKeyPathC9valueTypeypXpvgZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Final"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10AnyKeyPathC9valueTypeypXpvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Final",
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s10AnyKeyPathC9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Final"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -65356,13 +71275,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10AnyKeyPathC9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Final"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65370,22 +71282,26 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10AnyKeyPathC9hashValueSivg",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Final"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10AnyKeyPathC9hashValueSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Final"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s10AnyKeyPathC4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Final",
-            "Effects"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -65398,16 +71314,51 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10AnyKeyPathC4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Final",
+            "Effects"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyKeyPath",
+              "printedName": "AnyKeyPath",
+              "usr": "s:s10AnyKeyPathC"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyKeyPath",
+              "printedName": "AnyKeyPath",
+              "usr": "s:s10AnyKeyPathC"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10AnyKeyPathC2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Final"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s10AnyKeyPathCABycfc",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -65415,227 +71366,245 @@
               "printedName": "AnyKeyPath",
               "usr": "s:s10AnyKeyPathC"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s10AnyKeyPathCABycfc",
+          "moduleName": "Swift",
+          "isInternal": true
         }
+      ],
+      "declKind": "Class",
+      "usr": "s:s10AnyKeyPathC",
+      "moduleName": "Swift",
+      "conformingProtocols": [
+        "Hashable",
+        "_AppendKeyPath",
+        "Equatable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "PartialKeyPath",
       "printedName": "PartialKeyPath",
-      "declKind": "Class",
-      "usr": "s:s14PartialKeyPathC",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Root>",
-      "superclassUsr": "s:s10AnyKeyPathC",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable",
-        "_AppendKeyPath"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s14PartialKeyPathCAByxGycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Root>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "PartialKeyPath",
-              "printedName": "PartialKeyPath<Root>",
-              "usr": "s:s14PartialKeyPathC",
+              "printedName": "PartialKeyPath<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Root"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s14PartialKeyPathC"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s14PartialKeyPathCAByxGycfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "overriding": true,
+          "implicit": true,
+          "isInternal": true
         }
+      ],
+      "declKind": "Class",
+      "usr": "s:s14PartialKeyPathC",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "superclassUsr": "s:s10AnyKeyPathC",
+      "superclassNames": [
+        "AnyKeyPath"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable",
+        "_AppendKeyPath"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "KeyPath",
       "printedName": "KeyPath",
-      "declKind": "Class",
-      "usr": "s:s7KeyPathC",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Root, Value>",
-      "superclassUsr": "s:s14PartialKeyPathC",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable",
-        "_AppendKeyPath"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s7KeyPathCAByxq_Gycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Root, Value>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyPath",
-              "printedName": "KeyPath<Root, Value>",
-              "usr": "s:s7KeyPathC",
+              "printedName": "KeyPath<τ_0_0, τ_0_1>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Root"
+                  "printedName": "τ_0_0"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Value"
+                  "printedName": "τ_0_1"
                 }
-              ]
+              ],
+              "usr": "s:s7KeyPathC"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7KeyPathCAByxq_Gycfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1>",
+          "overriding": true,
+          "implicit": true,
+          "isInternal": true
         }
+      ],
+      "declKind": "Class",
+      "usr": "s:s7KeyPathC",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1>",
+      "superclassUsr": "s:s14PartialKeyPathC",
+      "superclassNames": [
+        "PartialKeyPath<τ_0_0>",
+        "AnyKeyPath"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable",
+        "_AppendKeyPath"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "WritableKeyPath",
       "printedName": "WritableKeyPath",
-      "declKind": "Class",
-      "usr": "s:s15WritableKeyPathC",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Root, Value>",
-      "superclassUsr": "s:s7KeyPathC",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable",
-        "_AppendKeyPath"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s15WritableKeyPathCAByxq_Gycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Root, Value>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "WritableKeyPath",
-              "printedName": "WritableKeyPath<Root, Value>",
-              "usr": "s:s15WritableKeyPathC",
+              "printedName": "WritableKeyPath<τ_0_0, τ_0_1>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Root"
+                  "printedName": "τ_0_0"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Value"
+                  "printedName": "τ_0_1"
                 }
-              ]
+              ],
+              "usr": "s:s15WritableKeyPathC"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s15WritableKeyPathCAByxq_Gycfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1>",
+          "overriding": true,
+          "implicit": true,
+          "isInternal": true
         }
+      ],
+      "declKind": "Class",
+      "usr": "s:s15WritableKeyPathC",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1>",
+      "superclassUsr": "s:s7KeyPathC",
+      "superclassNames": [
+        "KeyPath<τ_0_0, τ_0_1>",
+        "PartialKeyPath<τ_0_0>",
+        "AnyKeyPath"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable",
+        "_AppendKeyPath"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "ReferenceWritableKeyPath",
       "printedName": "ReferenceWritableKeyPath",
-      "declKind": "Class",
-      "usr": "s:s24ReferenceWritableKeyPathC",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Root, Value>",
-      "superclassUsr": "s:s15WritableKeyPathC",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable",
-        "_AppendKeyPath"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s24ReferenceWritableKeyPathCAByxq_Gycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Root, Value>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ReferenceWritableKeyPath",
-              "printedName": "ReferenceWritableKeyPath<Root, Value>",
-              "usr": "s:s24ReferenceWritableKeyPathC",
+              "printedName": "ReferenceWritableKeyPath<τ_0_0, τ_0_1>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Root"
+                  "printedName": "τ_0_0"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Value"
+                  "printedName": "τ_0_1"
                 }
-              ]
+              ],
+              "usr": "s:s24ReferenceWritableKeyPathC"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s24ReferenceWritableKeyPathCAByxq_Gycfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1>",
+          "overriding": true,
+          "implicit": true,
+          "isInternal": true
         }
+      ],
+      "declKind": "Class",
+      "usr": "s:s24ReferenceWritableKeyPathC",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1>",
+      "superclassUsr": "s:s15WritableKeyPathC",
+      "superclassNames": [
+        "WritableKeyPath<τ_0_0, τ_0_1>",
+        "KeyPath<τ_0_0, τ_0_1>",
+        "PartialKeyPath<τ_0_0>",
+        "AnyKeyPath"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable",
+        "_AppendKeyPath"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "_AppendKeyPath",
       "printedName": "_AppendKeyPath",
-      "declKind": "Protocol",
-      "usr": "s:s14_AppendKeyPathP",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "ShowInInterface"
-      ],
       "children": [
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
-          "declKind": "Func",
-          "usr": "s:s14_AppendKeyPathPss03AnybC0CRszrlE9appending4pathADSgAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self == AnyKeyPath>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "AnyKeyPath?",
-              "usr": "s:Sq",
+              "printedName": "Optional<AnyKeyPath>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65643,7 +71612,8 @@
                   "printedName": "AnyKeyPath",
                   "usr": "s:s10AnyKeyPathC"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -65651,41 +71621,40 @@
               "printedName": "AnyKeyPath",
               "usr": "s:s10AnyKeyPathC"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14_AppendKeyPathPss03AnybC0CRszrlE9appending4pathADSgAD_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 == AnyKeyPath>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
-          "declKind": "Func",
-          "usr": "s:s14_AppendKeyPathPsE9appending4paths07PartialbC0Cyqd__GSgs03AnybC0C_tAGRszlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Root where Self == PartialKeyPath<Root>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "PartialKeyPath<Root>?",
-              "usr": "s:Sq",
+              "printedName": "Optional<PartialKeyPath<τ_1_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "PartialKeyPath",
-                  "printedName": "PartialKeyPath<Root>",
-                  "usr": "s:s14PartialKeyPathC",
+                  "printedName": "PartialKeyPath<τ_1_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Root"
+                      "printedName": "τ_1_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s14PartialKeyPathC"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -65693,1440 +71662,574 @@
               "printedName": "AnyKeyPath",
               "usr": "s:s10AnyKeyPathC"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14_AppendKeyPathPsE9appending4paths07PartialbC0Cyqd__GSgs03AnybC0C_tAGRszlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == PartialKeyPath<τ_1_0>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
-          "declKind": "Func",
-          "usr": "s:s14_AppendKeyPathPsE9appending4paths0bC0Cyqd__qd_1_GSgAFyqd_0_qd_1_G_ts07PartialbC0Cyqd__GRszr1_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Root, AppendedRoot, AppendedValue where Self == PartialKeyPath<Root>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "KeyPath<Root, AppendedValue>?",
-              "usr": "s:Sq",
+              "printedName": "Optional<KeyPath<τ_1_0, τ_1_2>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "KeyPath",
-                  "printedName": "KeyPath<Root, AppendedValue>",
-                  "usr": "s:s7KeyPathC",
+                  "printedName": "KeyPath<τ_1_0, τ_1_2>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Root"
+                      "printedName": "τ_1_0"
                     },
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "AppendedValue"
+                      "printedName": "τ_1_2"
                     }
-                  ]
+                  ],
+                  "usr": "s:s7KeyPathC"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "KeyPath",
-              "printedName": "KeyPath<AppendedRoot, AppendedValue>",
-              "usr": "s:s7KeyPathC",
+              "printedName": "KeyPath<τ_1_1, τ_1_2>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "AppendedRoot"
+                  "printedName": "τ_1_1"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "AppendedValue"
+                  "printedName": "τ_1_2"
                 }
-              ]
+              ],
+              "usr": "s:s7KeyPathC"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14_AppendKeyPathPsE9appending4paths0bC0Cyqd__qd_1_GSgAFyqd_0_qd_1_G_ts07PartialbC0Cyqd__GRszr1_lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0, τ_1_1, τ_1_2 where τ_0_0 == PartialKeyPath<τ_1_0>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
-          "declKind": "Func",
-          "usr": "s:s14_AppendKeyPathPsE9appending4paths017ReferenceWritablebC0Cyqd__qd_1_GSgAFyqd_0_qd_1_G_ts07PartialbC0Cyqd__GRszr1_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Root, AppendedRoot, AppendedValue where Self == PartialKeyPath<Root>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "ReferenceWritableKeyPath<Root, AppendedValue>?",
-              "usr": "s:Sq",
+              "printedName": "Optional<ReferenceWritableKeyPath<τ_1_0, τ_1_2>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ReferenceWritableKeyPath",
-                  "printedName": "ReferenceWritableKeyPath<Root, AppendedValue>",
-                  "usr": "s:s24ReferenceWritableKeyPathC",
+                  "printedName": "ReferenceWritableKeyPath<τ_1_0, τ_1_2>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Root"
+                      "printedName": "τ_1_0"
                     },
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "AppendedValue"
+                      "printedName": "τ_1_2"
                     }
-                  ]
+                  ],
+                  "usr": "s:s24ReferenceWritableKeyPathC"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "ReferenceWritableKeyPath",
-              "printedName": "ReferenceWritableKeyPath<AppendedRoot, AppendedValue>",
-              "usr": "s:s24ReferenceWritableKeyPathC",
+              "printedName": "ReferenceWritableKeyPath<τ_1_1, τ_1_2>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "AppendedRoot"
+                  "printedName": "τ_1_1"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "AppendedValue"
+                  "printedName": "τ_1_2"
                 }
-              ]
+              ],
+              "usr": "s:s24ReferenceWritableKeyPathC"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14_AppendKeyPathPsE9appending4paths017ReferenceWritablebC0Cyqd__qd_1_GSgAFyqd_0_qd_1_G_ts07PartialbC0Cyqd__GRszr1_lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0, τ_1_1, τ_1_2 where τ_0_0 == PartialKeyPath<τ_1_0>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "KeyPath",
+              "printedName": "KeyPath<τ_1_0, τ_1_2>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_2"
+                }
+              ],
+              "usr": "s:s7KeyPathC"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "KeyPath",
+              "printedName": "KeyPath<τ_1_1, τ_1_2>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_1"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_2"
+                }
+              ],
+              "usr": "s:s7KeyPathC"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:s14_AppendKeyPathPsE9appending4paths0bC0Cyqd__qd_1_GAFyqd_0_qd_1_G_tAFyqd__qd_0_GRbzr1_lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, Root, Value, AppendedValue where Self : KeyPath<Root, Value>>",
+          "genericSig": "<τ_0_0, τ_1_0, τ_1_1, τ_1_2 where τ_0_0 : KeyPath<τ_1_0, τ_1_1>>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "KeyPath",
-              "printedName": "KeyPath<Root, AppendedValue>",
-              "usr": "s:s7KeyPathC",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Root"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "AppendedValue"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "KeyPath",
-              "printedName": "KeyPath<Value, AppendedValue>",
-              "usr": "s:s7KeyPathC",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "AppendedValue"
-                }
-              ]
-            }
           ]
         },
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ReferenceWritableKeyPath",
+              "printedName": "ReferenceWritableKeyPath<τ_1_0, τ_1_2>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_2"
+                }
+              ],
+              "usr": "s:s24ReferenceWritableKeyPathC"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ReferenceWritableKeyPath",
+              "printedName": "ReferenceWritableKeyPath<τ_1_1, τ_1_2>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_1"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_2"
+                }
+              ],
+              "usr": "s:s24ReferenceWritableKeyPathC"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:s14_AppendKeyPathPsE9appending4paths017ReferenceWritablebC0Cyqd__qd_1_GAFyqd_0_qd_1_G_ts0bC0Cyqd__qd_0_GRszr1_lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, Root, Value, AppendedValue where Self == KeyPath<Root, Value>>",
+          "genericSig": "<τ_0_0, τ_1_0, τ_1_1, τ_1_2 where τ_0_0 == KeyPath<τ_1_0, τ_1_1>>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ReferenceWritableKeyPath",
-              "printedName": "ReferenceWritableKeyPath<Root, AppendedValue>",
-              "usr": "s:s24ReferenceWritableKeyPathC",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Root"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "AppendedValue"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "ReferenceWritableKeyPath",
-              "printedName": "ReferenceWritableKeyPath<Value, AppendedValue>",
-              "usr": "s:s24ReferenceWritableKeyPathC",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "AppendedValue"
-                }
-              ]
-            }
           ]
         },
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "WritableKeyPath",
+              "printedName": "WritableKeyPath<τ_1_0, τ_1_2>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_2"
+                }
+              ],
+              "usr": "s:s15WritableKeyPathC"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "WritableKeyPath",
+              "printedName": "WritableKeyPath<τ_1_1, τ_1_2>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_1"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_2"
+                }
+              ],
+              "usr": "s:s15WritableKeyPathC"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:s14_AppendKeyPathPsE9appending4paths08WritablebC0Cyqd__qd_1_GAFyqd_0_qd_1_G_tAFyqd__qd_0_GRszr1_lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, Root, Value, AppendedValue where Self == WritableKeyPath<Root, Value>>",
+          "genericSig": "<τ_0_0, τ_1_0, τ_1_1, τ_1_2 where τ_0_0 == WritableKeyPath<τ_1_0, τ_1_1>>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "WritableKeyPath",
-              "printedName": "WritableKeyPath<Root, AppendedValue>",
-              "usr": "s:s15WritableKeyPathC",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Root"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "AppendedValue"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "WritableKeyPath",
-              "printedName": "WritableKeyPath<Value, AppendedValue>",
-              "usr": "s:s15WritableKeyPathC",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "AppendedValue"
-                }
-              ]
-            }
           ]
         },
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ReferenceWritableKeyPath",
+              "printedName": "ReferenceWritableKeyPath<τ_1_0, τ_1_2>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_2"
+                }
+              ],
+              "usr": "s:s24ReferenceWritableKeyPathC"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ReferenceWritableKeyPath",
+              "printedName": "ReferenceWritableKeyPath<τ_1_1, τ_1_2>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_1"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_2"
+                }
+              ],
+              "usr": "s:s24ReferenceWritableKeyPathC"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:s14_AppendKeyPathPsE9appending4paths017ReferenceWritablebC0Cyqd__qd_1_GAFyqd_0_qd_1_G_ts0gbC0Cyqd__qd_0_GRszr1_lF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self, Root, Value, AppendedValue where Self == WritableKeyPath<Root, Value>>",
+          "genericSig": "<τ_0_0, τ_1_0, τ_1_1, τ_1_2 where τ_0_0 == WritableKeyPath<τ_1_0, τ_1_1>>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ReferenceWritableKeyPath",
-              "printedName": "ReferenceWritableKeyPath<Root, AppendedValue>",
-              "usr": "s:s24ReferenceWritableKeyPathC",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Root"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "AppendedValue"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "ReferenceWritableKeyPath",
-              "printedName": "ReferenceWritableKeyPath<Value, AppendedValue>",
-              "usr": "s:s24ReferenceWritableKeyPathC",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "AppendedValue"
-                }
-              ]
-            }
           ]
         },
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
-          "declKind": "Func",
-          "usr": "s:s14_AppendKeyPathPsE9appending4paths017ReferenceWritablebC0Cyqd__qd_1_Gs0gbC0Cyqd_0_qd_1_G_tAFyqd__qd_0_GRszr1_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Root, Value, AppendedValue where Self == ReferenceWritableKeyPath<Root, Value>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ReferenceWritableKeyPath",
-              "printedName": "ReferenceWritableKeyPath<Root, AppendedValue>",
-              "usr": "s:s24ReferenceWritableKeyPathC",
+              "printedName": "ReferenceWritableKeyPath<τ_1_0, τ_1_2>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Root"
+                  "printedName": "τ_1_0"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "AppendedValue"
+                  "printedName": "τ_1_2"
                 }
-              ]
+              ],
+              "usr": "s:s24ReferenceWritableKeyPathC"
             },
             {
               "kind": "TypeNominal",
               "name": "WritableKeyPath",
-              "printedName": "WritableKeyPath<Value, AppendedValue>",
-              "usr": "s:s15WritableKeyPathC",
+              "printedName": "WritableKeyPath<τ_1_1, τ_1_2>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Value"
+                  "printedName": "τ_1_1"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "AppendedValue"
+                  "printedName": "τ_1_2"
                 }
-              ]
+              ],
+              "usr": "s:s15WritableKeyPathC"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14_AppendKeyPathPsE9appending4paths017ReferenceWritablebC0Cyqd__qd_1_Gs0gbC0Cyqd_0_qd_1_G_tAFyqd__qd_0_GRszr1_lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0, τ_1_1, τ_1_2 where τ_0_0 == ReferenceWritableKeyPath<τ_1_0, τ_1_1>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s14_AppendKeyPathP",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "ShowInInterface"
       ]
     },
     {
       "kind": "TypeDecl",
-      "name": "LazyCollectionProtocol",
-      "printedName": "LazyCollectionProtocol",
-      "declKind": "Protocol",
-      "usr": "s:s22LazyCollectionProtocolP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Collection, Self : LazySequenceProtocol, Self.Elements : Collection>",
-      "conformingProtocols": [
-        "Collection",
-        "LazySequenceProtocol",
-        "Sequence"
-      ],
+      "name": "KeyValuePairs",
+      "printedName": "KeyValuePairs",
       "children": [
         {
-          "kind": "Function",
-          "name": "drop",
-          "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsE4drop5whiles0a9DropWhileB0Vy8ElementsQzGSb7ElementQzc_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LazyCollectionProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "kind": "Var",
+          "name": "_elements",
+          "printedName": "_elements",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "LazyDropWhileCollection",
-              "printedName": "LazyDropWhileCollection<Self.Elements>",
-              "usr": "s:s23LazyDropWhileCollectionV",
+              "name": "Array",
+              "printedName": "Array<(τ_0_0, τ_0_1)>",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Elements"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Elements.Element) -> Bool",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Elements.Element)",
+                  "name": "Tuple",
+                  "printedName": "(τ_0_0, τ_0_1)",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements.Element"
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
                     }
                   ]
                 }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "filter",
-          "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsE6filterys0a6FilterB0Vy8ElementsQzGSb7ElementQzcF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LazyCollectionProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyFilterCollection",
-              "printedName": "LazyFilterCollection<Self.Elements>",
-              "usr": "s:s20LazyFilterCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Elements"
-                }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Elements.Element) -> Bool",
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Elements.Element)",
+                  "name": "Array",
+                  "printedName": "Array<(τ_0_0, τ_0_1)>",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "flatMap",
-          "printedName": "flatMap(_:)",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsE7flatMapys0aB0Vys07FlattenB0Vys0aeB0Vy8ElementsQzqd__GGGqd__7ElementQzcSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, SegmentOfResult where Self : LazyCollectionProtocol, SegmentOfResult : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyCollection",
-              "printedName": "LazyCollection<FlattenCollection<LazyMapCollection<Self.Elements, SegmentOfResult>>>",
-              "usr": "s:s14LazyCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "FlattenCollection",
-                  "printedName": "FlattenCollection<LazyMapCollection<Self.Elements, SegmentOfResult>>",
-                  "usr": "s:s17FlattenCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "LazyMapCollection",
-                      "printedName": "LazyMapCollection<Self.Elements, SegmentOfResult>",
-                      "usr": "s:s17LazyMapCollectionV",
+                      "name": "Tuple",
+                      "printedName": "(τ_0_0, τ_0_1)",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "DependentMember",
-                          "printedName": "Self.Elements"
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
                         },
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
-                          "printedName": "SegmentOfResult"
+                          "printedName": "τ_0_1"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Elements.Element) -> SegmentOfResult",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "SegmentOfResult"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Elements.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements.Element"
-                    }
-                  ]
-                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13KeyValuePairsV9_elementsSayx_q_tGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s13KeyValuePairsV9_elementsSayx_q_tGvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
         },
         {
-          "kind": "Function",
-          "name": "compactMap",
-          "printedName": "compactMap(_:)",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsE10compactMapys0aeB0Vys0a6FilterB0VyAEy8ElementsQzqd__SgGGqd__GAJ7ElementQzclF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, ElementOfResult where Self : LazyCollectionProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(dictionaryLiteral:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "LazyMapCollection",
-              "printedName": "LazyMapCollection<LazyFilterCollection<LazyMapCollection<Self.Elements, ElementOfResult?>>, ElementOfResult>",
-              "usr": "s:s17LazyMapCollectionV",
+              "name": "KeyValuePairs",
+              "printedName": "KeyValuePairs<τ_0_0, τ_0_1>",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "LazyFilterCollection",
-                  "printedName": "LazyFilterCollection<LazyMapCollection<Self.Elements, ElementOfResult?>>",
-                  "usr": "s:s20LazyFilterCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "LazyMapCollection",
-                      "printedName": "LazyMapCollection<Self.Elements, ElementOfResult?>",
-                      "usr": "s:s17LazyMapCollectionV",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "DependentMember",
-                          "printedName": "Self.Elements"
-                        },
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Optional",
-                          "printedName": "ElementOfResult?",
-                          "usr": "s:Sq",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GenericTypeParam",
-                              "printedName": "ElementOfResult"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "ElementOfResult"
+                  "printedName": "τ_0_1"
                 }
-              ]
+              ],
+              "usr": "s:s13KeyValuePairsV"
             },
             {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Elements.Element) -> ElementOfResult?",
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<(τ_0_0, τ_0_1)>",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "ElementOfResult?",
-                  "usr": "s:Sq",
+                  "name": "Tuple",
+                  "printedName": "(τ_0_0, τ_0_1)",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "ElementOfResult"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Elements.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "joined",
-          "printedName": "joined()",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsSl7ElementRpzrlE6joineds0aB0Vys07FlattenB0Vy8ElementsQzGGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LazyCollectionProtocol, Self.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyCollection",
-              "printedName": "LazyCollection<FlattenCollection<Self.Elements>>",
-              "usr": "s:s14LazyCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "FlattenCollection",
-                  "printedName": "FlattenCollection<Self.Elements>",
-                  "usr": "s:s17FlattenCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "lazy",
-          "printedName": "lazy",
-          "declKind": "Var",
-          "usr": "s:s22LazyCollectionProtocolPsE4lazys0aB0Vy8ElementsQzGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyCollection",
-              "printedName": "LazyCollection<Self.Elements>",
-              "usr": "s:s14LazyCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Elements"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s22LazyCollectionProtocolPsE4lazys0aB0Vy8ElementsQzGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : LazyCollectionProtocol>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "LazyCollection",
-                  "printedName": "LazyCollection<Self.Elements>",
-                  "usr": "s:s14LazyCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "lazy",
-          "printedName": "lazy",
-          "declKind": "Var",
-          "usr": "s:s22LazyCollectionProtocolPssAA8ElementsRpzrlE4lazyADvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Elements"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s22LazyCollectionProtocolPssAA8ElementsRpzrlE4lazyADvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : LazyCollectionProtocol, Self.Elements : LazyCollectionProtocol>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Elements"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "map",
-          "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsE3mapys0a3MapB0Vy8ElementsQzqd__Gqd__7ElementQzclF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, U where Self : LazyCollectionProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyMapCollection",
-              "printedName": "LazyMapCollection<Self.Elements, U>",
-              "usr": "s:s17LazyMapCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Elements"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "U"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Elements.Element) -> U",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "U"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Elements.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "prefix",
-          "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsE6prefix5whiles0a11PrefixWhileB0Vy8ElementsQzGSb7ElementQzc_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LazyCollectionProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyPrefixWhileCollection",
-              "printedName": "LazyPrefixWhileCollection<Self.Elements>",
-              "usr": "s:s25LazyPrefixWhileCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Elements"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Element) -> Bool",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "reversed",
-          "printedName": "reversed()",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsSKRzSK8Elementss0a8SequenceC0PRpzrlE8reverseds0aB0Vys08ReversedB0VyAFGGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self : LazyCollectionProtocol, Self.Elements : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyCollection",
-              "printedName": "LazyCollection<ReversedCollection<Self.Elements>>",
-              "usr": "s:s14LazyCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "ReversedCollection",
-                  "printedName": "ReversedCollection<Self.Elements>",
-                  "usr": "s:s18ReversedCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "flatMap",
-          "printedName": "flatMap(_:)",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsE7flatMapys0aeB0Vys0a6FilterB0VyAEy8ElementsQzqd__SgGGqd__GAJ7ElementQzclF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, ElementOfResult where Self : LazyCollectionProtocol>",
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyMapCollection",
-              "printedName": "LazyMapCollection<LazyFilterCollection<LazyMapCollection<Self.Elements, ElementOfResult?>>, ElementOfResult>",
-              "usr": "s:s17LazyMapCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "LazyFilterCollection",
-                  "printedName": "LazyFilterCollection<LazyMapCollection<Self.Elements, ElementOfResult?>>",
-                  "usr": "s:s20LazyFilterCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "LazyMapCollection",
-                      "printedName": "LazyMapCollection<Self.Elements, ElementOfResult?>",
-                      "usr": "s:s17LazyMapCollectionV",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "DependentMember",
-                          "printedName": "Self.Elements"
-                        },
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Optional",
-                          "printedName": "ElementOfResult?",
-                          "usr": "s:Sq",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GenericTypeParam",
-                              "printedName": "ElementOfResult"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "ElementOfResult"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Elements.Element) -> ElementOfResult?",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "ElementOfResult?",
-                  "usr": "s:Sq",
-                  "children": [
+                      "printedName": "τ_0_0"
+                    },
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "ElementOfResult"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Elements.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements.Element"
+                      "printedName": "τ_0_1"
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "LazyCollection",
-      "printedName": "LazyCollection",
-      "declKind": "Struct",
-      "usr": "s:s14LazyCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Collection>",
-      "conformingProtocols": [
-        "LazyCollectionProtocol",
-        "LazySequenceProtocol",
-        "Sequence",
-        "Collection",
-        "BidirectionalCollection",
-        "RandomAccessCollection"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "TypeAlias",
-          "name": "Elements",
-          "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s14LazyCollectionV8Elementsa",
-          "location": "",
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13KeyValuePairsV17dictionaryLiteralAByxq_Gx_q_td_tcfc",
           "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Base"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "elements",
-          "printedName": "elements",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionV8elementsxvp",
-          "location": "",
-          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Base"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionV8elementsxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s14LazyCollectionV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Iterator"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "makeIterator",
-          "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s14LazyCollectionV12makeIterator0D0QzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Iterator",
-              "printedName": "LazyCollection<Base>.Iterator",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Iterator"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "underestimatedCount",
-          "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s14LazyCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s14LazyCollectionV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Index"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s14LazyCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Indices"
-            }
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionV10startIndex0D0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Index"
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionV10startIndex0D0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Index"
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13KeyValuePairsV10startIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13KeyValuePairsV10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionV8endIndex0D0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Index"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionV8endIndex0D0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "indices",
-          "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionV7indices7IndicesQzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Indices"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionV7indices7IndicesQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Indices"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s14LazyCollectionV5index5after5IndexQzAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isEmpty",
-          "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionV7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionV7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "count",
-          "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -67138,11 +72241,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -67150,2453 +72248,39 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "first",
-          "printedName": "first",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionV5first7ElementQzSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Base.Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Element"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionV5first7ElementQzSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "Base.Element?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Base.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s14LazyCollectionV5index_8offsetBy5IndexQzAF_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s14LazyCollectionV5index_8offsetBy07limitedE05IndexQzSgAG_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "LazyCollection<Base>.Index?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "LazyCollection<Base>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "τ_0_0.Index"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s14LazyCollectionV8distance4from2toSi5IndexQz_AGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s14LazyCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<LazyCollection<Base>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "LazyCollection",
-                  "printedName": "LazyCollection<Base>",
-                  "usr": "s:s14LazyCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Base"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s14LazyCollectionVsSKRzrlE5index6before5IndexQzAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyCollection<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "last",
-          "printedName": "last",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionVsSKRzrlE4last7ElementQzSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Base.Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Element"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionVsSKRzrlE4last7ElementQzSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "Base.Element?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Base.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "LazySequenceProtocol",
-      "printedName": "LazySequenceProtocol",
-      "declKind": "Protocol",
-      "usr": "s:s20LazySequenceProtocolP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Sequence, Self.Element == Self.Elements.Element, Self.Elements : Sequence>",
-      "conformingProtocols": [
-        "Sequence"
-      ],
-      "children": [
-        {
-          "kind": "Var",
-          "name": "elements",
-          "printedName": "elements",
-          "declKind": "Var",
-          "usr": "s:s20LazySequenceProtocolP8elements8ElementsQzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Elements"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20LazySequenceProtocolP8elements8ElementsQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : LazySequenceProtocol>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Elements"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "drop",
-          "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:s20LazySequenceProtocolPsE4drop5whiles0a9DropWhileB0Vy8ElementsQzGSb7ElementQzc_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LazySequenceProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyDropWhileSequence",
-              "printedName": "LazyDropWhileSequence<Self.Elements>",
-              "usr": "s:s21LazyDropWhileSequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Elements"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Elements.Element) -> Bool",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Elements.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "filter",
-          "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:s20LazySequenceProtocolPsE6filterys0a6FilterB0Vy8ElementsQzGSb7ElementQzcF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LazySequenceProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyFilterSequence",
-              "printedName": "LazyFilterSequence<Self.Elements>",
-              "usr": "s:s18LazyFilterSequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Elements"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Elements.Element) -> Bool",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Elements.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "flatMap",
-          "printedName": "flatMap(_:)",
-          "declKind": "Func",
-          "usr": "s:s20LazySequenceProtocolPsE7flatMapys0aB0Vys07FlattenB0Vys0aeB0Vy8ElementsQzqd__GGGqd__7ElementQzcSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, SegmentOfResult where Self : LazySequenceProtocol, SegmentOfResult : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazySequence",
-              "printedName": "LazySequence<FlattenSequence<LazyMapSequence<Self.Elements, SegmentOfResult>>>",
-              "usr": "s:s12LazySequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "FlattenSequence",
-                  "printedName": "FlattenSequence<LazyMapSequence<Self.Elements, SegmentOfResult>>",
-                  "usr": "s:s15FlattenSequenceV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "LazyMapSequence",
-                      "printedName": "LazyMapSequence<Self.Elements, SegmentOfResult>",
-                      "usr": "s:s15LazyMapSequenceV",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "DependentMember",
-                          "printedName": "Self.Elements"
-                        },
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "SegmentOfResult"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Elements.Element) -> SegmentOfResult",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "SegmentOfResult"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Elements.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "compactMap",
-          "printedName": "compactMap(_:)",
-          "declKind": "Func",
-          "usr": "s:s20LazySequenceProtocolPsE10compactMapys0aeB0Vys0a6FilterB0VyAEy8ElementsQzqd__SgGGqd__GAJ7ElementQzclF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, ElementOfResult where Self : LazySequenceProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyMapSequence",
-              "printedName": "LazyMapSequence<LazyFilterSequence<LazyMapSequence<Self.Elements, ElementOfResult?>>, ElementOfResult>",
-              "usr": "s:s15LazyMapSequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "LazyFilterSequence",
-                  "printedName": "LazyFilterSequence<LazyMapSequence<Self.Elements, ElementOfResult?>>",
-                  "usr": "s:s18LazyFilterSequenceV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "LazyMapSequence",
-                      "printedName": "LazyMapSequence<Self.Elements, ElementOfResult?>",
-                      "usr": "s:s15LazyMapSequenceV",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "DependentMember",
-                          "printedName": "Self.Elements"
-                        },
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Optional",
-                          "printedName": "ElementOfResult?",
-                          "usr": "s:Sq",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GenericTypeParam",
-                              "printedName": "ElementOfResult"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "ElementOfResult"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Elements.Element) -> ElementOfResult?",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "ElementOfResult?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "ElementOfResult"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Elements.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "joined",
-          "printedName": "joined()",
-          "declKind": "Func",
-          "usr": "s:s20LazySequenceProtocolPsST7ElementRpzrlE6joineds0aB0Vys07FlattenB0Vy8ElementsQzGGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LazySequenceProtocol, Self.Element : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazySequence",
-              "printedName": "LazySequence<FlattenSequence<Self.Elements>>",
-              "usr": "s:s12LazySequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "FlattenSequence",
-                  "printedName": "FlattenSequence<Self.Elements>",
-                  "usr": "s:s15FlattenSequenceV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "elements",
-          "printedName": "elements",
-          "declKind": "Var",
-          "usr": "s:s20LazySequenceProtocolPs8ElementsQzRszrlE8elementsxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20LazySequenceProtocolPs8ElementsQzRszrlE8elementsxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : LazySequenceProtocol, Self == Self.Elements>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "lazy",
-          "printedName": "lazy",
-          "declKind": "Var",
-          "usr": "s:s20LazySequenceProtocolPsE4lazys0aB0Vy8ElementsQzGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazySequence",
-              "printedName": "LazySequence<Self.Elements>",
-              "usr": "s:s12LazySequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Elements"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20LazySequenceProtocolPsE4lazys0aB0Vy8ElementsQzGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : LazySequenceProtocol>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "LazySequence",
-                  "printedName": "LazySequence<Self.Elements>",
-                  "usr": "s:s12LazySequenceV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "lazy",
-          "printedName": "lazy",
-          "declKind": "Var",
-          "usr": "s:s20LazySequenceProtocolPssAA8ElementsRpzrlE4lazyADvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Elements"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20LazySequenceProtocolPssAA8ElementsRpzrlE4lazyADvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : LazySequenceProtocol, Self.Elements : LazySequenceProtocol>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Elements"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "map",
-          "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:s20LazySequenceProtocolPsE3mapys0a3MapB0Vy8ElementsQzqd__Gqd__7ElementQzclF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, U where Self : LazySequenceProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyMapSequence",
-              "printedName": "LazyMapSequence<Self.Elements, U>",
-              "usr": "s:s15LazyMapSequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Elements"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "U"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Elements.Element) -> U",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "U"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Elements.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "prefix",
-          "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:s20LazySequenceProtocolPsE6prefix5whiles0a11PrefixWhileB0Vy8ElementsQzGSb7ElementQzc_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LazySequenceProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyPrefixWhileSequence",
-              "printedName": "LazyPrefixWhileSequence<Self.Elements>",
-              "usr": "s:s23LazyPrefixWhileSequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Elements"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Elements.Element) -> Bool",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Elements.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "flatMap",
-          "printedName": "flatMap(_:)",
-          "declKind": "Func",
-          "usr": "s:s20LazySequenceProtocolPsE7flatMapys0aeB0Vys0a6FilterB0VyAEy8ElementsQzqd__SgGGqd__GAJ7ElementQzclF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, ElementOfResult where Self : LazySequenceProtocol>",
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyMapSequence",
-              "printedName": "LazyMapSequence<LazyFilterSequence<LazyMapSequence<Self.Elements, ElementOfResult?>>, ElementOfResult>",
-              "usr": "s:s15LazyMapSequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "LazyFilterSequence",
-                  "printedName": "LazyFilterSequence<LazyMapSequence<Self.Elements, ElementOfResult?>>",
-                  "usr": "s:s18LazyFilterSequenceV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "LazyMapSequence",
-                      "printedName": "LazyMapSequence<Self.Elements, ElementOfResult?>",
-                      "usr": "s:s15LazyMapSequenceV",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "DependentMember",
-                          "printedName": "Self.Elements"
-                        },
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Optional",
-                          "printedName": "ElementOfResult?",
-                          "usr": "s:Sq",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GenericTypeParam",
-                              "printedName": "ElementOfResult"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "ElementOfResult"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Elements.Element) -> ElementOfResult?",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "ElementOfResult?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "ElementOfResult"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Elements.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Elements.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "LazySequence",
-      "printedName": "LazySequence",
-      "declKind": "Struct",
-      "usr": "s:s12LazySequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Sequence>",
-      "conformingProtocols": [
-        "_SequenceWrapper",
-        "Sequence",
-        "LazySequenceProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "TypeAlias",
-          "name": "Base",
-          "printedName": "Base",
-          "declKind": "TypeAlias",
-          "usr": "s:s12LazySequenceV4Basea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Base"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s12LazySequenceV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Iterator"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s12LazySequenceV03SubB0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.SubSequence"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s12LazySequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Elements",
-          "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s12LazySequenceV8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Base"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "elements",
-          "printedName": "elements",
-          "declKind": "Var",
-          "usr": "s:s12LazySequenceV8elementsxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Base"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12LazySequenceV8elementsxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "Function",
-      "name": "withExtendedLifetime",
-      "printedName": "withExtendedLifetime(_:_:)",
-      "declKind": "Func",
-      "usr": "s:s20withExtendedLifetimeyq_x_q_yKXEtKr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, Result>",
-      "throwing": true,
-      "declAttributes": [
-        "Rethrows",
-        "Inlinable"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "Result"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        },
-        {
-          "kind": "TypeFunc",
-          "name": "Function",
-          "printedName": "() throws -> Result",
-          "typeAttributes": [
-            "noescape"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Result"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "Function",
-      "name": "withExtendedLifetime",
-      "printedName": "withExtendedLifetime(_:_:)",
-      "declKind": "Func",
-      "usr": "s:s20withExtendedLifetimeyq_x_q_xKXEtKr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, Result>",
-      "throwing": true,
-      "declAttributes": [
-        "Rethrows",
-        "Inlinable"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "Result"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        },
-        {
-          "kind": "TypeFunc",
-          "name": "Function",
-          "printedName": "(T) throws -> Result",
-          "typeAttributes": [
-            "noescape"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Result"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Paren",
-              "printedName": "(T)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "Function",
-      "name": "withUnsafeMutablePointer",
-      "printedName": "withUnsafeMutablePointer(to:_:)",
-      "declKind": "Func",
-      "usr": "s:s24withUnsafeMutablePointer2to_q_xz_q_SpyxGKXEtKr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, Result>",
-      "throwing": true,
-      "declAttributes": [
-        "Rethrows",
-        "Inlinable"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "Result"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        },
-        {
-          "kind": "TypeFunc",
-          "name": "Function",
-          "printedName": "(UnsafeMutablePointer<T>) throws -> Result",
-          "typeAttributes": [
-            "noescape"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Result"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Paren",
-              "printedName": "(UnsafeMutablePointer<T>)",
-              "usr": "s:Sp",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafeMutablePointer",
-                  "printedName": "UnsafeMutablePointer<T>",
-                  "usr": "s:Sp",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "T"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "Function",
-      "name": "withUnsafePointer",
-      "printedName": "withUnsafePointer(to:_:)",
-      "declKind": "Func",
-      "usr": "s:s17withUnsafePointer2to_q_x_q_SPyxGKXEtKr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, Result>",
-      "throwing": true,
-      "declAttributes": [
-        "Rethrows",
-        "Inlinable"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "Result"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        },
-        {
-          "kind": "TypeFunc",
-          "name": "Function",
-          "printedName": "(UnsafePointer<T>) throws -> Result",
-          "typeAttributes": [
-            "noescape"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Result"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Paren",
-              "printedName": "(UnsafePointer<T>)",
-              "usr": "s:SP",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafePointer",
-                  "printedName": "UnsafePointer<T>",
-                  "usr": "s:SP",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "T"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "Function",
-      "name": "withUnsafePointer",
-      "printedName": "withUnsafePointer(to:_:)",
-      "declKind": "Func",
-      "usr": "s:s17withUnsafePointer2to_q_xz_q_SPyxGKXEtKr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, Result>",
-      "throwing": true,
-      "declAttributes": [
-        "Rethrows",
-        "Inlinable"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "Result"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        },
-        {
-          "kind": "TypeFunc",
-          "name": "Function",
-          "printedName": "(UnsafePointer<T>) throws -> Result",
-          "typeAttributes": [
-            "noescape"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Result"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Paren",
-              "printedName": "(UnsafePointer<T>)",
-              "usr": "s:SP",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafePointer",
-                  "printedName": "UnsafePointer<T>",
-                  "usr": "s:SP",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "T"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "ManagedBuffer",
-      "printedName": "ManagedBuffer",
-      "declKind": "Class",
-      "usr": "s:s13ManagedBufferC",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Header, Element>",
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Function",
-          "name": "create",
-          "printedName": "create(minimumCapacity:makingHeaderWith:)",
-          "declKind": "Func",
-          "usr": "s:s13ManagedBufferC6create15minimumCapacity16makingHeaderWithAByxq_GSi_xAFKXEtKFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element>",
-          "static": true,
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Final",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ManagedBuffer",
-              "printedName": "ManagedBuffer<Header, Element>",
-              "usr": "s:s13ManagedBufferC",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Header"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(ManagedBuffer<Header, Element>) throws -> Header",
-              "typeAttributes": [
-                "noescape"
               ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Header"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(ManagedBuffer<Header, Element>)",
-                  "usr": "s:s13ManagedBufferC",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "ManagedBuffer",
-                      "printedName": "ManagedBuffer<Header, Element>",
-                      "usr": "s:s13ManagedBufferC",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Header"
-                        },
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Element"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
+              "declKind": "Accessor",
+              "usr": "s:s13KeyValuePairsV8endIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1>"
             }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "capacity",
-          "printedName": "capacity",
+          ],
           "declKind": "Var",
-          "usr": "s:s13ManagedBufferC8capacitySivp",
-          "location": "",
+          "usr": "s:s13KeyValuePairsV8endIndexSivp",
           "moduleName": "Swift",
           "declAttributes": [
-            "Final",
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13ManagedBufferC8capacitySivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Header, Element>",
-              "declAttributes": [
-                "Final"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
           ]
         },
         {
-          "kind": "Function",
-          "name": "withUnsafeMutablePointerToHeader",
-          "printedName": "withUnsafeMutablePointerToHeader(_:)",
-          "declKind": "Func",
-          "usr": "s:s13ManagedBufferC32withUnsafeMutablePointerToHeaderyqd__qd__SpyxGKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Final",
-            "Inlinable"
-          ],
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafeMutablePointer<Header>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "name": "Tuple",
+              "printedName": "(key: τ_0_0, value: τ_0_1)",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeMutablePointer<Header>)",
-                  "usr": "s:Sp",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeMutablePointer",
-                      "printedName": "UnsafeMutablePointer<Header>",
-                      "usr": "s:Sp",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Header"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeMutablePointerToElements",
-          "printedName": "withUnsafeMutablePointerToElements(_:)",
-          "declKind": "Func",
-          "usr": "s:s13ManagedBufferC34withUnsafeMutablePointerToElementsyqd__qd__Spyq_GKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Final",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafeMutablePointer<Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeMutablePointer<Element>)",
-                  "usr": "s:Sp",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeMutablePointer",
-                      "printedName": "UnsafeMutablePointer<Element>",
-                      "usr": "s:Sp",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Element"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeMutablePointers",
-          "printedName": "withUnsafeMutablePointers(_:)",
-          "declKind": "Func",
-          "usr": "s:s13ManagedBufferC25withUnsafeMutablePointersyqd__qd__SpyxG_Spyq_GtKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Final",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafeMutablePointer<Header>, UnsafeMutablePointer<Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(UnsafeMutablePointer<Header>, UnsafeMutablePointer<Element>)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeMutablePointer",
-                      "printedName": "UnsafeMutablePointer<Header>",
-                      "usr": "s:Sp",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Header"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeMutablePointer",
-                      "printedName": "UnsafeMutablePointer<Element>",
-                      "usr": "s:Sp",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Element"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "header",
-          "printedName": "header",
-          "declKind": "Var",
-          "usr": "s:s13ManagedBufferC6headerxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Final"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Header"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13ManagedBufferC6headerxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Header, Element>",
-              "declAttributes": [
-                "Transparent",
-                "Final"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Header"
-                }
-              ]
-            },
-            {
-              "kind": "Setter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13ManagedBufferC6headerxvs",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Header, Element>",
-              "declAttributes": [
-                "Transparent",
-                "Final"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
+                  "printedName": "τ_0_0"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Header"
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "ManagedBufferPointer",
-      "printedName": "ManagedBufferPointer",
-      "declKind": "Struct",
-      "usr": "s:s20ManagedBufferPointerV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Header, Element>",
-      "conformingProtocols": [
-        "Equatable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(bufferClass:minimumCapacity:makingHeaderWith:)",
-          "declKind": "Constructor",
-          "usr": "s:s20ManagedBufferPointerV11bufferClass15minimumCapacity16makingHeaderWithAByxq_GyXlXp_SixyXl_SiyXlXEtKXEtKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ManagedBufferPointer",
-              "printedName": "ManagedBufferPointer<Header, Element>",
-              "usr": "s:s20ManagedBufferPointerV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Header"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "AnyClass",
-              "printedName": "AnyClass",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "ExistentialMetatype",
-                  "printedName": "AnyObject.Type",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "ProtocolComposition",
-                      "printedName": "AnyObject"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(AnyObject, (AnyObject) -> Int) throws -> Header",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Header"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(AnyObject, (AnyObject) -> Int)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "AnyObject",
-                      "printedName": "AnyObject",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "ProtocolComposition",
-                          "printedName": "AnyObject"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeFunc",
-                      "name": "Function",
-                      "printedName": "(AnyObject) -> Int",
-                      "typeAttributes": [
-                        "noescape"
-                      ],
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Int",
-                          "printedName": "Int",
-                          "usr": "s:Si"
-                        },
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Paren",
-                          "printedName": "(AnyObject)",
-                          "children": [
-                            {
-                              "kind": "TypeNameAlias",
-                              "name": "AnyObject",
-                              "printedName": "AnyObject",
-                              "children": [
-                                {
-                                  "kind": "TypeNominal",
-                                  "name": "ProtocolComposition",
-                                  "printedName": "AnyObject"
-                                }
-                              ]
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(unsafeBufferObject:)",
-          "declKind": "Constructor",
-          "usr": "s:s20ManagedBufferPointerV06unsafeB6ObjectAByxq_GyXl_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ManagedBufferPointer",
-              "printedName": "ManagedBufferPointer<Header, Element>",
-              "usr": "s:s20ManagedBufferPointerV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Header"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "AnyObject",
-              "printedName": "AnyObject",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "ProtocolComposition",
-                  "printedName": "AnyObject"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "header",
-          "printedName": "header",
-          "declKind": "Var",
-          "usr": "s:s20ManagedBufferPointerV6headerxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Header"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20ManagedBufferPointerV6headerxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Header, Element>",
-              "declAttributes": [
-                "Transparent"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Header"
-                }
-              ]
-            },
-            {
-              "kind": "Setter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20ManagedBufferPointerV6headerxvs",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Header, Element>",
-              "mutating": true,
-              "declAttributes": [
-                "Transparent"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Header"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "buffer",
-          "printedName": "buffer",
-          "declKind": "Var",
-          "usr": "s:s20ManagedBufferPointerV6bufferyXlvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "AnyObject",
-              "printedName": "AnyObject",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "ProtocolComposition",
-                  "printedName": "AnyObject"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20ManagedBufferPointerV6bufferyXlvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Header, Element>",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "AnyObject",
-                  "printedName": "AnyObject",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "ProtocolComposition",
-                      "printedName": "AnyObject"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "capacity",
-          "printedName": "capacity",
-          "declKind": "Var",
-          "usr": "s:s20ManagedBufferPointerV8capacitySivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20ManagedBufferPointerV8capacitySivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Header, Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeMutablePointerToHeader",
-          "printedName": "withUnsafeMutablePointerToHeader(_:)",
-          "declKind": "Func",
-          "usr": "s:s20ManagedBufferPointerV017withUnsafeMutableC8ToHeaderyqd__qd__SpyxGKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafeMutablePointer<Header>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeMutablePointer<Header>)",
-                  "usr": "s:Sp",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeMutablePointer",
-                      "printedName": "UnsafeMutablePointer<Header>",
-                      "usr": "s:Sp",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Header"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeMutablePointerToElements",
-          "printedName": "withUnsafeMutablePointerToElements(_:)",
-          "declKind": "Func",
-          "usr": "s:s20ManagedBufferPointerV017withUnsafeMutableC10ToElementsyqd__qd__Spyq_GKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafeMutablePointer<Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeMutablePointer<Element>)",
-                  "usr": "s:Sp",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeMutablePointer",
-                      "printedName": "UnsafeMutablePointer<Element>",
-                      "usr": "s:Sp",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Element"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeMutablePointers",
-          "printedName": "withUnsafeMutablePointers(_:)",
-          "declKind": "Func",
-          "usr": "s:s20ManagedBufferPointerV25withUnsafeMutablePointersyqd__qd__SpyxG_Spyq_GtKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafeMutablePointer<Header>, UnsafeMutablePointer<Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(UnsafeMutablePointer<Header>, UnsafeMutablePointer<Element>)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeMutablePointer",
-                      "printedName": "UnsafeMutablePointer<Header>",
-                      "usr": "s:Sp",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Header"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeMutablePointer",
-                      "printedName": "UnsafeMutablePointer<Element>",
-                      "usr": "s:Sp",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Element"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isUniqueReference",
-          "printedName": "isUniqueReference()",
-          "declKind": "Func",
-          "usr": "s:s20ManagedBufferPointerV17isUniqueReferenceSbyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(bufferClass:minimumCapacity:)",
-          "declKind": "Constructor",
-          "usr": "s:s20ManagedBufferPointerV11bufferClass15minimumCapacityAByxq_GyXlXp_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ManagedBufferPointer",
-              "printedName": "ManagedBufferPointer<Header, Element>",
-              "usr": "s:s20ManagedBufferPointerV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Header"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "AnyClass",
-              "printedName": "AnyClass",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "ExistentialMetatype",
-                  "printedName": "AnyObject.Type",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "ProtocolComposition",
-                      "printedName": "AnyObject"
-                    }
-                  ]
+                  "printedName": "τ_0_1"
                 }
               ]
             },
@@ -69606,2039 +72290,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s20ManagedBufferPointerVyAByxq_Gs0aB0Cyxq_Gcfc",
-          "location": "",
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s13KeyValuePairsVyx3key_q_5valuetSicip",
           "moduleName": "Swift",
-          "genericSig": "<Header, Element>",
+          "genericSig": "<τ_0_0, τ_0_1>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ManagedBufferPointer",
-              "printedName": "ManagedBufferPointer<Header, Element>",
-              "usr": "s:s20ManagedBufferPointerV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Header"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "ManagedBuffer",
-              "printedName": "ManagedBuffer<Header, Element>",
-              "usr": "s:s13ManagedBufferC",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Header"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:_:_:)",
-          "declKind": "Constructor",
-          "usr": "s:s20ManagedBufferPointerVss05_HeapB7Header_RzrlEyAByxq_GyXlXp_5ValueQzSitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element where Header : _HeapBufferHeader_>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ManagedBufferPointer",
-              "printedName": "ManagedBufferPointer<Header, Element>",
-              "usr": "s:s20ManagedBufferPointerV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Header"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "AnyClass",
-              "printedName": "AnyClass",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "ExistentialMetatype",
-                  "printedName": "AnyObject.Type",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "ProtocolComposition",
-                      "printedName": "AnyObject"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Value",
-              "printedName": "ManagedBufferPointer<Header, Element>.Value",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Value"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "Function",
-      "name": "isKnownUniquelyReferenced",
-      "printedName": "isKnownUniquelyReferenced(_:)",
-      "declKind": "Func",
-      "usr": "s:s25isKnownUniquelyReferencedySbxzRlzClF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : AnyObject>",
-      "declAttributes": [
-        "Inlinable"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Bool",
-          "printedName": "Bool",
-          "usr": "s:Sb"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        }
-      ]
-    },
-    {
-      "kind": "Function",
-      "name": "isKnownUniquelyReferenced",
-      "printedName": "isKnownUniquelyReferenced(_:)",
-      "declKind": "Func",
-      "usr": "s:s25isKnownUniquelyReferencedySbxSgzRlzClF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : AnyObject>",
-      "declAttributes": [
-        "Inlinable"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Bool",
-          "printedName": "Bool",
-          "usr": "s:Sb"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "Optional",
-          "printedName": "T?",
-          "usr": "s:Sq",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "LazyMapSequence",
-      "printedName": "LazyMapSequence",
-      "declKind": "Struct",
-      "usr": "s:s15LazyMapSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base, Element where Base : Sequence>",
-      "conformingProtocols": [
-        "LazySequenceProtocol",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "TypeAlias",
-          "name": "Elements",
-          "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s15LazyMapSequenceV8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyMapSequence",
-              "printedName": "LazyMapSequence<Base, Element>",
-              "usr": "s:s15LazyMapSequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeDecl",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s15LazyMapSequenceV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Sequence>",
-          "conformingProtocols": [
-            "IteratorProtocol",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "Var",
-              "name": "base",
-              "printedName": "base",
-              "declKind": "Var",
-              "usr": "s:s15LazyMapSequenceV8IteratorV4baseACQzvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Iterator"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s15LazyMapSequenceV8IteratorV4baseACQzvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Base, Element where Base : Sequence>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Base.Iterator"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "next",
-              "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s15LazyMapSequenceV8IteratorV4nextq_SgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Sequence>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "Element?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s15LazyMapSequenceV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Sequence>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s15LazyMapSequenceV8IteratorVACa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Sequence>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "LazyMapSequence<Base, Element>.Iterator",
-                  "usr": "s:s15LazyMapSequenceV8IteratorV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s15LazyMapSequenceV8IteratorV03SubC0a",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Sequence>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnySequence",
-                  "printedName": "AnySequence<Element>",
-                  "usr": "s:s11AnySequenceV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "makeIterator",
-          "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s15LazyMapSequenceV12makeIteratorAB0E0Vyxq__GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Iterator",
-              "printedName": "LazyMapSequence<Base, Element>.Iterator",
-              "usr": "s:s15LazyMapSequenceV8IteratorV"
-            }
           ]
         },
         {
           "kind": "Var",
-          "name": "underestimatedCount",
-          "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s15LazyMapSequenceV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15LazyMapSequenceV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Sequence>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s15LazyMapSequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s15LazyMapSequenceV03SubC0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnySequence",
-              "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "LazyMapCollection",
-      "printedName": "LazyMapCollection",
-      "declKind": "Struct",
-      "usr": "s:s17LazyMapCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base, Element where Base : Collection>",
-      "conformingProtocols": [
-        "Sequence",
-        "LazyCollectionProtocol",
-        "Collection",
-        "LazySequenceProtocol",
-        "BidirectionalCollection",
-        "RandomAccessCollection"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s17LazyMapCollectionV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Iterator",
-              "printedName": "LazyMapSequence<Base, Element>.Iterator",
-              "usr": "s:s15LazyMapSequenceV8IteratorV"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "makeIterator",
-          "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s17LazyMapCollectionV12makeIterators0aB8SequenceV0E0Vyxq__GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Iterator",
-              "printedName": "LazyMapCollection<Base, Element>.Iterator",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "LazyMapSequence<τ_0_0, τ_0_1>.Iterator",
-                  "usr": "s:s15LazyMapSequenceV8IteratorV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "underestimatedCount",
-          "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s17LazyMapCollectionV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17LazyMapCollectionV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s17LazyMapCollectionV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Index"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s17LazyMapCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Indices"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s17LazyMapCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyMapCollection",
-              "printedName": "LazyMapCollection<Base.SubSequence, Element>",
-              "usr": "s:s17LazyMapCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.SubSequence"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s17LazyMapCollectionV10startIndex0E0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Index"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17LazyMapCollectionV10startIndex0E0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s17LazyMapCollectionV8endIndex0E0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Index"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17LazyMapCollectionV8endIndex0E0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s17LazyMapCollectionV5index5after5IndexQzAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyMapCollection<Base, Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyMapCollection<Base, Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s17LazyMapCollectionV9formIndex5aftery0E0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyMapCollection<Base, Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "indices",
-          "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:s17LazyMapCollectionV7indices7IndicesQzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Indices"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17LazyMapCollectionV7indices7IndicesQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Indices"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isEmpty",
-          "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:s17LazyMapCollectionV7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17LazyMapCollectionV7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "count",
-          "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s17LazyMapCollectionV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17LazyMapCollectionV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "first",
-          "printedName": "first",
-          "declKind": "Var",
-          "usr": "s:s17LazyMapCollectionV5firstq_Sgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17LazyMapCollectionV5firstq_Sgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "Element?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s17LazyMapCollectionV5index_8offsetBy5IndexQzAF_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyMapCollection<Base, Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyMapCollection<Base, Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s17LazyMapCollectionV5index_8offsetBy07limitedF05IndexQzSgAG_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "LazyMapCollection<Base, Element>.Index?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "LazyMapCollection<Base, Element>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "τ_0_0.Index"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyMapCollection<Base, Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyMapCollection<Base, Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s17LazyMapCollectionV8distance4from2toSi5IndexQz_AGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyMapCollection<Base, Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyMapCollection<Base, Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Elements",
-          "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s17LazyMapCollectionV8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyMapCollection",
-              "printedName": "LazyMapCollection<Base, Element>",
-              "usr": "s:s17LazyMapCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s17LazyMapCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s17LazyMapCollectionVsSKRzrlE5index6before5IndexQzAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyMapCollection<Base, Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyMapCollection<Base, Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:s17LazyMapCollectionVsSKRzrlE9formIndex6beforey0E0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "LazyMapCollection<Base, Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "last",
-          "printedName": "last",
-          "declKind": "Var",
-          "usr": "s:s17LazyMapCollectionVsSKRzrlE4lastq_Sgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17LazyMapCollectionVsSKRzrlE4lastq_Sgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : BidirectionalCollection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "Element?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "MemoryLayout",
-      "printedName": "MemoryLayout",
-      "declKind": "Enum",
-      "usr": "s:s12MemoryLayoutO",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "declAttributes": [
-        "Frozen"
-      ],
-      "children": [
-        {
-          "kind": "Var",
-          "name": "size",
-          "printedName": "size",
-          "declKind": "Var",
-          "usr": "s:s12MemoryLayoutO4sizeSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12MemoryLayoutO4sizeSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<T>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "stride",
-          "printedName": "stride",
-          "declKind": "Var",
-          "usr": "s:s12MemoryLayoutO6strideSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12MemoryLayoutO6strideSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<T>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "alignment",
-          "printedName": "alignment",
-          "declKind": "Var",
-          "usr": "s:s12MemoryLayoutO9alignmentSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12MemoryLayoutO9alignmentSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<T>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "size",
-          "printedName": "size(ofValue:)",
-          "declKind": "Func",
-          "usr": "s:s12MemoryLayoutO4size7ofValueSix_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "stride",
-          "printedName": "stride(ofValue:)",
-          "declKind": "Func",
-          "usr": "s:s12MemoryLayoutO6stride7ofValueSix_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "alignment",
-          "printedName": "alignment(ofValue:)",
-          "declKind": "Func",
-          "usr": "s:s12MemoryLayoutO9alignment7ofValueSix_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "offset",
-          "printedName": "offset(of:)",
-          "declKind": "Func",
-          "usr": "s:s12MemoryLayoutO6offset2ofSiSgs14PartialKeyPathCyxG_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "PartialKeyPath",
-              "printedName": "PartialKeyPath<T>",
-              "usr": "s:s14PartialKeyPathC",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "MutableCollection",
-      "printedName": "MutableCollection",
-      "declKind": "Protocol",
-      "usr": "s:SM",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Collection, Self.SubSequence : MutableCollection>",
-      "conformingProtocols": [
-        "Collection",
-        "Sequence"
-      ],
-      "children": [
-        {
-          "kind": "Function",
-          "name": "partition",
-          "printedName": "partition(by:)",
-          "declKind": "Func",
-          "usr": "s:SM9partition2by5IndexQzSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : MutableCollection>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Index"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "swapAt",
-          "printedName": "swapAt(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SM6swapAtyy5IndexQz_ACtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : MutableCollection>",
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Index"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Index"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "partition",
-          "printedName": "partition(by:)",
-          "declKind": "Func",
-          "usr": "s:SMsE9partition2by5IndexQzSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : MutableCollection>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Index"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "partition",
-          "printedName": "partition(by:)",
-          "declKind": "Func",
-          "usr": "s:SMsSKRzrlE9partition2by5IndexSlQzSb7ElementSTQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self : MutableCollection>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Index"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "shuffle",
-          "printedName": "shuffle(using:)",
-          "declKind": "Func",
-          "usr": "s:SMsSkRzrlE7shuffle5usingyqd__z_tSGRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : MutableCollection, Self : RandomAccessCollection, T : RandomNumberGenerator>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "shuffle",
-          "printedName": "shuffle()",
-          "declKind": "Func",
-          "usr": "s:SMsSkRzrlE7shuffleyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : MutableCollection, Self : RandomAccessCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "swapAt",
-          "printedName": "swapAt(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SMsE6swapAtyy5IndexQz_ACtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : MutableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Index"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Index"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "reverse",
-          "printedName": "reverse()",
-          "declKind": "Func",
-          "usr": "s:SMsSKRzrlE7reverseyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self : MutableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "sort",
-          "printedName": "sort()",
-          "declKind": "Func",
-          "usr": "s:SMsSkRzSL7ElementSTRpzrlE4sortyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : MutableCollection, Self : RandomAccessCollection, Self.Element : Comparable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "sort",
-          "printedName": "sort(by:)",
-          "declKind": "Func",
-          "usr": "s:SMsSkRzrlE4sort2byySb7ElementSTQz_ADtKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : MutableCollection, Self : RandomAccessCollection>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Element, Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(Self.Element, Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "Function",
-      "name": "swap",
-      "printedName": "swap(_:_:)",
-      "declKind": "Func",
-      "usr": "s:s4swapyyxz_xztlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "declAttributes": [
-        "Inlinable"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Void",
-          "printedName": "()"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "ObjectIdentifier",
-      "printedName": "ObjectIdentifier",
-      "declKind": "Struct",
-      "usr": "s:SO",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "CustomDebugStringConvertible",
-        "Equatable",
-        "Comparable",
-        "Hashable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SOySOyXlcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ObjectIdentifier",
-              "printedName": "ObjectIdentifier",
-              "usr": "s:SO"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "AnyObject",
-              "printedName": "AnyObject",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "ProtocolComposition",
-                  "printedName": "AnyObject"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SOySOypXpcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ObjectIdentifier",
-              "printedName": "ObjectIdentifier",
-              "usr": "s:SO"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "ExistentialMetatype",
-              "printedName": "Any.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "ProtocolComposition",
-                  "printedName": "Any"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "debugDescription",
-          "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:SO16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
+          "name": "description",
+          "printedName": "description",
           "children": [
             {
               "kind": "TypeNominal",
@@ -71650,10 +72314,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SO16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -71661,21 +72321,5564 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13KeyValuePairsV11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13KeyValuePairsV11descriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13KeyValuePairsV16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13KeyValuePairsV16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s13KeyValuePairsV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "ExpressibleByDictionaryLiteral",
+        "RandomAccessCollection",
+        "BidirectionalCollection",
+        "Collection",
+        "Sequence",
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "LazyCollectionProtocol",
+      "printedName": "LazyCollectionProtocol",
+      "children": [
+        {
+          "kind": "AssociatedType",
+          "name": "Elements",
+          "printedName": "Elements",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:s22LazyCollectionProtocolP8ElementsQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "Function",
+          "name": "drop",
+          "printedName": "drop(while:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyDropWhileCollection",
+              "printedName": "LazyDropWhileCollection<τ_0_0.Elements>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements"
+                }
+              ],
+              "usr": "s:s23LazyDropWhileCollectionV"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Elements.Element) -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements.Element"
+                }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsE4drop5whiles0a9DropWhileB0Vy8ElementsQzGSb7ElementQzc_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : LazyCollectionProtocol>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "filter",
+          "printedName": "filter(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyFilterCollection",
+              "printedName": "LazyFilterCollection<τ_0_0.Elements>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements"
+                }
+              ],
+              "usr": "s:s20LazyFilterCollectionV"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Elements.Element) -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements.Element"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsE6filterys0a6FilterB0Vy8ElementsQzGSb7ElementQzcF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : LazyCollectionProtocol>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "flatMap",
+          "printedName": "flatMap(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyCollection",
+              "printedName": "LazyCollection<FlattenCollection<LazyMapCollection<τ_0_0.Elements, τ_1_0>>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "FlattenCollection",
+                  "printedName": "FlattenCollection<LazyMapCollection<τ_0_0.Elements, τ_1_0>>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "LazyMapCollection",
+                      "printedName": "LazyMapCollection<τ_0_0.Elements, τ_1_0>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "DependentMember",
+                          "printedName": "τ_0_0.Elements"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_1_0"
+                        }
+                      ],
+                      "usr": "s:s17LazyMapCollectionV"
+                    }
+                  ],
+                  "usr": "s:s17FlattenCollectionV"
+                }
+              ],
+              "usr": "s:s14LazyCollectionV"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Elements.Element) -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements.Element"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsE7flatMapys0aB0Vys07FlattenB0Vys0aeB0Vy8ElementsQzqd__GGGqd__7ElementQzcSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : LazyCollectionProtocol, τ_1_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "compactMap",
+          "printedName": "compactMap(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyMapCollection",
+              "printedName": "LazyMapCollection<LazyFilterCollection<LazyMapCollection<τ_0_0.Elements, Optional<τ_1_0>>>, τ_1_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "LazyFilterCollection",
+                  "printedName": "LazyFilterCollection<LazyMapCollection<τ_0_0.Elements, Optional<τ_1_0>>>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "LazyMapCollection",
+                      "printedName": "LazyMapCollection<τ_0_0.Elements, Optional<τ_1_0>>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "DependentMember",
+                          "printedName": "τ_0_0.Elements"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Optional",
+                          "printedName": "Optional<τ_1_0>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "GenericTypeParam",
+                              "printedName": "τ_1_0"
+                            }
+                          ],
+                          "usr": "s:Sq"
+                        }
+                      ],
+                      "usr": "s:s17LazyMapCollectionV"
+                    }
+                  ],
+                  "usr": "s:s20LazyFilterCollectionV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                }
+              ],
+              "usr": "s:s17LazyMapCollectionV"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Elements.Element) -> Optional<τ_1_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_1_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_1_0"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements.Element"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsE10compactMapys0aeB0Vys0a6FilterB0VyAEy8ElementsQzqd__SgGGqd__GAJ7ElementQzclF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : LazyCollectionProtocol>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "joined",
+          "printedName": "joined()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyCollection",
+              "printedName": "LazyCollection<FlattenCollection<τ_0_0.Elements>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "FlattenCollection",
+                  "printedName": "FlattenCollection<τ_0_0.Elements>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Elements"
+                    }
+                  ],
+                  "usr": "s:s17FlattenCollectionV"
+                }
+              ],
+              "usr": "s:s14LazyCollectionV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsSl7ElementRpzrlE6joineds0aB0Vys07FlattenB0Vy8ElementsQzGGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : LazyCollectionProtocol, τ_0_0.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "lazy",
+          "printedName": "lazy",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyCollection",
+              "printedName": "LazyCollection<τ_0_0.Elements>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements"
+                }
+              ],
+              "usr": "s:s14LazyCollectionV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "LazyCollection",
+                  "printedName": "LazyCollection<τ_0_0.Elements>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Elements"
+                    }
+                  ],
+                  "usr": "s:s14LazyCollectionV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s22LazyCollectionProtocolPsE4lazys0aB0Vy8ElementsQzGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : LazyCollectionProtocol>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s22LazyCollectionProtocolPsE4lazys0aB0Vy8ElementsQzGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "lazy",
+          "printedName": "lazy",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Elements"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s22LazyCollectionProtocolPssAA8ElementsRpzrlE4lazyADvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : LazyCollectionProtocol, τ_0_0.Elements : LazyCollectionProtocol>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s22LazyCollectionProtocolPssAA8ElementsRpzrlE4lazyADvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "map",
+          "printedName": "map(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyMapCollection",
+              "printedName": "LazyMapCollection<τ_0_0.Elements, τ_1_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                }
+              ],
+              "usr": "s:s17LazyMapCollectionV"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Elements.Element) -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements.Element"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsE3mapys0a3MapB0Vy8ElementsQzqd__Gqd__7ElementQzclF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : LazyCollectionProtocol>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "prefix",
+          "printedName": "prefix(while:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyPrefixWhileCollection",
+              "printedName": "LazyPrefixWhileCollection<τ_0_0.Elements>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements"
+                }
+              ],
+              "usr": "s:s25LazyPrefixWhileCollectionV"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Element) -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsE6prefix5whiles0a11PrefixWhileB0Vy8ElementsQzGSb7ElementQzc_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : LazyCollectionProtocol>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "reversed",
+          "printedName": "reversed()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyCollection",
+              "printedName": "LazyCollection<ReversedCollection<τ_0_0.Elements>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ReversedCollection",
+                  "printedName": "ReversedCollection<τ_0_0.Elements>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Elements"
+                    }
+                  ],
+                  "usr": "s:s18ReversedCollectionV"
+                }
+              ],
+              "usr": "s:s14LazyCollectionV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsSKRzSK8Elementss0a8SequenceC0PRpzrlE8reverseds0aB0Vys08ReversedB0VyAFGGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0 : LazyCollectionProtocol, τ_0_0.Elements : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "flatMap",
+          "printedName": "flatMap(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyMapCollection",
+              "printedName": "LazyMapCollection<LazyFilterCollection<LazyMapCollection<τ_0_0.Elements, Optional<τ_1_0>>>, τ_1_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "LazyFilterCollection",
+                  "printedName": "LazyFilterCollection<LazyMapCollection<τ_0_0.Elements, Optional<τ_1_0>>>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "LazyMapCollection",
+                      "printedName": "LazyMapCollection<τ_0_0.Elements, Optional<τ_1_0>>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "DependentMember",
+                          "printedName": "τ_0_0.Elements"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Optional",
+                          "printedName": "Optional<τ_1_0>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "GenericTypeParam",
+                              "printedName": "τ_1_0"
+                            }
+                          ],
+                          "usr": "s:Sq"
+                        }
+                      ],
+                      "usr": "s:s17LazyMapCollectionV"
+                    }
+                  ],
+                  "usr": "s:s20LazyFilterCollectionV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                }
+              ],
+              "usr": "s:s17LazyMapCollectionV"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Elements.Element) -> Optional<τ_1_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_1_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_1_0"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements.Element"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsE7flatMapys0aeB0Vys0a6FilterB0VyAEy8ElementsQzqd__SgGGqd__GAJ7ElementQzclF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : LazyCollectionProtocol>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
+          ]
+        }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s22LazyCollectionProtocolP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : Collection, τ_0_0 : LazySequenceProtocol, τ_0_0.Elements : Collection>",
+      "conformingProtocols": [
+        "Collection",
+        "LazySequenceProtocol",
+        "Sequence"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "LazyCollection",
+      "printedName": "LazyCollection",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_base",
+          "printedName": "_base",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionV5_basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionV5_basexvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "elements",
+          "printedName": "elements",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionV8elementsxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionV8elementsxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "makeIterator",
+          "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Iterator"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14LazyCollectionV12makeIterator0D0QzyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "underestimatedCount",
+          "printedName": "underestimatedCount",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionV10startIndex0D0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionV10startIndex0D0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionV8endIndex0D0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionV8endIndex0D0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "indices",
+          "printedName": "indices",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Indices"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Indices"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionV7indices7IndicesQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionV7indices7IndicesQzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14LazyCollectionV5index5after5IndexQzAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s14LazyCollectionVy7ElementQz5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isEmpty",
+          "printedName": "isEmpty",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionV7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionV7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "count",
+          "printedName": "count",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "first",
+          "printedName": "first",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0.Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_0.Element>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionV5first7ElementQzSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionV5first7ElementQzSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14LazyCollectionV5index_8offsetBy5IndexQzAF_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:limitedBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14LazyCollectionV5index_8offsetBy07limitedE05IndexQzSgAG_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(from:to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14LazyCollectionV8distance4from2toSi5IndexQz_AGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14LazyCollectionVsSKRzrlE5index6before5IndexQzAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "last",
+          "printedName": "last",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0.Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_0.Element>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionVsSKRzrlE4last7ElementQzSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionVsSKRzrlE4last7ElementQzSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s14LazyCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "LazyCollectionProtocol",
+        "LazySequenceProtocol",
+        "Sequence",
+        "Collection",
+        "BidirectionalCollection",
+        "RandomAccessCollection"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "LazySequenceProtocol",
+      "printedName": "LazySequenceProtocol",
+      "children": [
+        {
+          "kind": "AssociatedType",
+          "name": "Elements",
+          "printedName": "Elements",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:s20LazySequenceProtocolP8ElementsQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "elements",
+          "printedName": "elements",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Elements"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20LazySequenceProtocolP8elements8ElementsQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : LazySequenceProtocol>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20LazySequenceProtocolP8elements8ElementsQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "drop",
+          "printedName": "drop(while:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyDropWhileSequence",
+              "printedName": "LazyDropWhileSequence<τ_0_0.Elements>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements"
+                }
+              ],
+              "usr": "s:s21LazyDropWhileSequenceV"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Elements.Element) -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements.Element"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazySequenceProtocolPsE4drop5whiles0a9DropWhileB0Vy8ElementsQzGSb7ElementQzc_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : LazySequenceProtocol>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "filter",
+          "printedName": "filter(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyFilterSequence",
+              "printedName": "LazyFilterSequence<τ_0_0.Elements>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements"
+                }
+              ],
+              "usr": "s:s18LazyFilterSequenceV"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Elements.Element) -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements.Element"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazySequenceProtocolPsE6filterys0a6FilterB0Vy8ElementsQzGSb7ElementQzcF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : LazySequenceProtocol>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "flatMap",
+          "printedName": "flatMap(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazySequence",
+              "printedName": "LazySequence<FlattenSequence<LazyMapSequence<τ_0_0.Elements, τ_1_0>>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "FlattenSequence",
+                  "printedName": "FlattenSequence<LazyMapSequence<τ_0_0.Elements, τ_1_0>>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "LazyMapSequence",
+                      "printedName": "LazyMapSequence<τ_0_0.Elements, τ_1_0>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "DependentMember",
+                          "printedName": "τ_0_0.Elements"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_1_0"
+                        }
+                      ],
+                      "usr": "s:s15LazyMapSequenceV"
+                    }
+                  ],
+                  "usr": "s:s15FlattenSequenceV"
+                }
+              ],
+              "usr": "s:s12LazySequenceV"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Elements.Element) -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements.Element"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazySequenceProtocolPsE7flatMapys0aB0Vys07FlattenB0Vys0aeB0Vy8ElementsQzqd__GGGqd__7ElementQzcSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : LazySequenceProtocol, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "compactMap",
+          "printedName": "compactMap(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyMapSequence",
+              "printedName": "LazyMapSequence<LazyFilterSequence<LazyMapSequence<τ_0_0.Elements, Optional<τ_1_0>>>, τ_1_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "LazyFilterSequence",
+                  "printedName": "LazyFilterSequence<LazyMapSequence<τ_0_0.Elements, Optional<τ_1_0>>>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "LazyMapSequence",
+                      "printedName": "LazyMapSequence<τ_0_0.Elements, Optional<τ_1_0>>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "DependentMember",
+                          "printedName": "τ_0_0.Elements"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Optional",
+                          "printedName": "Optional<τ_1_0>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "GenericTypeParam",
+                              "printedName": "τ_1_0"
+                            }
+                          ],
+                          "usr": "s:Sq"
+                        }
+                      ],
+                      "usr": "s:s15LazyMapSequenceV"
+                    }
+                  ],
+                  "usr": "s:s18LazyFilterSequenceV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                }
+              ],
+              "usr": "s:s15LazyMapSequenceV"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Elements.Element) -> Optional<τ_1_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_1_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_1_0"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements.Element"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazySequenceProtocolPsE10compactMapys0aeB0Vys0a6FilterB0VyAEy8ElementsQzqd__SgGGqd__GAJ7ElementQzclF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : LazySequenceProtocol>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "joined",
+          "printedName": "joined()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazySequence",
+              "printedName": "LazySequence<FlattenSequence<τ_0_0.Elements>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "FlattenSequence",
+                  "printedName": "FlattenSequence<τ_0_0.Elements>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Elements"
+                    }
+                  ],
+                  "usr": "s:s15FlattenSequenceV"
+                }
+              ],
+              "usr": "s:s12LazySequenceV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazySequenceProtocolPsST7ElementRpzrlE6joineds0aB0Vys07FlattenB0Vy8ElementsQzGGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : LazySequenceProtocol, τ_0_0.Element : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "elements",
+          "printedName": "elements",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20LazySequenceProtocolPs8ElementsQzRszrlE8elementsxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : LazySequenceProtocol, τ_0_0 == τ_0_0.Elements>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20LazySequenceProtocolPs8ElementsQzRszrlE8elementsxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "lazy",
+          "printedName": "lazy",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazySequence",
+              "printedName": "LazySequence<τ_0_0.Elements>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements"
+                }
+              ],
+              "usr": "s:s12LazySequenceV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "LazySequence",
+                  "printedName": "LazySequence<τ_0_0.Elements>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Elements"
+                    }
+                  ],
+                  "usr": "s:s12LazySequenceV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20LazySequenceProtocolPsE4lazys0aB0Vy8ElementsQzGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : LazySequenceProtocol>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20LazySequenceProtocolPsE4lazys0aB0Vy8ElementsQzGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "lazy",
+          "printedName": "lazy",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Elements"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20LazySequenceProtocolPssAA8ElementsRpzrlE4lazyADvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : LazySequenceProtocol, τ_0_0.Elements : LazySequenceProtocol>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20LazySequenceProtocolPssAA8ElementsRpzrlE4lazyADvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "map",
+          "printedName": "map(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyMapSequence",
+              "printedName": "LazyMapSequence<τ_0_0.Elements, τ_1_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                }
+              ],
+              "usr": "s:s15LazyMapSequenceV"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Elements.Element) -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements.Element"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazySequenceProtocolPsE3mapys0a3MapB0Vy8ElementsQzqd__Gqd__7ElementQzclF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : LazySequenceProtocol>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "prefix",
+          "printedName": "prefix(while:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyPrefixWhileSequence",
+              "printedName": "LazyPrefixWhileSequence<τ_0_0.Elements>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements"
+                }
+              ],
+              "usr": "s:s23LazyPrefixWhileSequenceV"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Elements.Element) -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements.Element"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazySequenceProtocolPsE6prefix5whiles0a11PrefixWhileB0Vy8ElementsQzGSb7ElementQzc_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : LazySequenceProtocol>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "flatMap",
+          "printedName": "flatMap(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyMapSequence",
+              "printedName": "LazyMapSequence<LazyFilterSequence<LazyMapSequence<τ_0_0.Elements, Optional<τ_1_0>>>, τ_1_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "LazyFilterSequence",
+                  "printedName": "LazyFilterSequence<LazyMapSequence<τ_0_0.Elements, Optional<τ_1_0>>>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "LazyMapSequence",
+                      "printedName": "LazyMapSequence<τ_0_0.Elements, Optional<τ_1_0>>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "DependentMember",
+                          "printedName": "τ_0_0.Elements"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Optional",
+                          "printedName": "Optional<τ_1_0>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "GenericTypeParam",
+                              "printedName": "τ_1_0"
+                            }
+                          ],
+                          "usr": "s:Sq"
+                        }
+                      ],
+                      "usr": "s:s15LazyMapSequenceV"
+                    }
+                  ],
+                  "usr": "s:s18LazyFilterSequenceV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                }
+              ],
+              "usr": "s:s15LazyMapSequenceV"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Elements.Element) -> Optional<τ_1_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_1_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_1_0"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Elements.Element"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazySequenceProtocolPsE7flatMapys0aeB0Vys0a6FilterB0VyAEy8ElementsQzqd__SgGGqd__GAJ7ElementQzclF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : LazySequenceProtocol>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
+          ]
+        }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s20LazySequenceProtocolP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : Sequence, τ_0_0.Element == τ_0_0.Elements.Element, τ_0_0.Elements : Sequence>",
+      "conformingProtocols": [
+        "Sequence"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "LazySequence",
+      "printedName": "LazySequence",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_base",
+          "printedName": "_base",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12LazySequenceV5_basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12LazySequenceV5_basexvs",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12LazySequenceV5_basexvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "elements",
+          "printedName": "elements",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12LazySequenceV8elementsxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12LazySequenceV8elementsxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s12LazySequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "_SequenceWrapper",
+        "Sequence",
+        "LazySequenceProtocol"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "withExtendedLifetime",
+      "printedName": "withExtendedLifetime(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_1"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeFunc",
+          "name": "Function",
+          "printedName": "() throws -> τ_0_1",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "typeAttributes": [
+            "noescape"
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s20withExtendedLifetimeyq_x_q_yKXEtKr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1>",
+      "declAttributes": [
+        "Rethrows",
+        "Inlinable"
+      ],
+      "throwing": true
+    },
+    {
+      "kind": "Function",
+      "name": "withExtendedLifetime",
+      "printedName": "withExtendedLifetime(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_1"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeFunc",
+          "name": "Function",
+          "printedName": "(τ_0_0) throws -> τ_0_1",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "typeAttributes": [
+            "noescape"
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s20withExtendedLifetimeyq_x_q_xKXEtKr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1>",
+      "declAttributes": [
+        "Rethrows",
+        "Inlinable"
+      ],
+      "throwing": true
+    },
+    {
+      "kind": "Function",
+      "name": "withUnsafeMutablePointer",
+      "printedName": "withUnsafeMutablePointer(to:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_1"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeFunc",
+          "name": "Function",
+          "printedName": "(UnsafeMutablePointer<τ_0_0>) throws -> τ_0_1",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutablePointer",
+              "printedName": "UnsafeMutablePointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sp"
+            }
+          ],
+          "typeAttributes": [
+            "noescape"
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s24withUnsafeMutablePointer2to_q_xz_q_SpyxGKXEtKr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1>",
+      "declAttributes": [
+        "Rethrows",
+        "Inlinable"
+      ],
+      "throwing": true
+    },
+    {
+      "kind": "Function",
+      "name": "withUnsafePointer",
+      "printedName": "withUnsafePointer(to:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_1"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeFunc",
+          "name": "Function",
+          "printedName": "(UnsafePointer<τ_0_0>) throws -> τ_0_1",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafePointer",
+              "printedName": "UnsafePointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SP"
+            }
+          ],
+          "typeAttributes": [
+            "noescape"
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s17withUnsafePointer2to_q_x_q_SPyxGKXEtKr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1>",
+      "declAttributes": [
+        "Rethrows",
+        "Inlinable"
+      ],
+      "throwing": true
+    },
+    {
+      "kind": "Function",
+      "name": "withUnsafePointer",
+      "printedName": "withUnsafePointer(to:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_1"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeFunc",
+          "name": "Function",
+          "printedName": "(UnsafePointer<τ_0_0>) throws -> τ_0_1",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafePointer",
+              "printedName": "UnsafePointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SP"
+            }
+          ],
+          "typeAttributes": [
+            "noescape"
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s17withUnsafePointer2to_q_xz_q_SPyxGKXEtKr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1>",
+      "declAttributes": [
+        "Rethrows",
+        "Inlinable"
+      ],
+      "throwing": true
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "ManagedBuffer",
+      "printedName": "ManagedBuffer",
+      "children": [
+        {
+          "kind": "Function",
+          "name": "create",
+          "printedName": "create(minimumCapacity:makingHeaderWith:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ManagedBuffer",
+              "printedName": "ManagedBuffer<τ_0_0, τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:s13ManagedBufferC"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(ManagedBuffer<τ_0_0, τ_0_1>) throws -> τ_0_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "ManagedBuffer",
+                  "printedName": "ManagedBuffer<τ_0_0, τ_0_1>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ],
+                  "usr": "s:s13ManagedBufferC"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13ManagedBufferC6create15minimumCapacity16makingHeaderWithAByxq_GSi_xAFKXEtKFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1>",
+          "static": true,
+          "declAttributes": [
+            "Rethrows",
+            "Final",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Var",
+          "name": "capacity",
+          "printedName": "capacity",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13ManagedBufferC8capacitySivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1>",
+              "declAttributes": [
+                "Final"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13ManagedBufferC8capacitySivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Final",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeMutablePointerToHeader",
+          "printedName": "withUnsafeMutablePointerToHeader(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafeMutablePointer<τ_0_0>) throws -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutablePointer",
+                  "printedName": "UnsafeMutablePointer<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:Sp"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13ManagedBufferC32withUnsafeMutablePointerToHeaderyqd__qd__SpyxGKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Final",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeMutablePointerToElements",
+          "printedName": "withUnsafeMutablePointerToElements(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafeMutablePointer<τ_0_1>) throws -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutablePointer",
+                  "printedName": "UnsafeMutablePointer<τ_0_1>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ],
+                  "usr": "s:Sp"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13ManagedBufferC34withUnsafeMutablePointerToElementsyqd__qd__Spyq_GKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Final",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeMutablePointers",
+          "printedName": "withUnsafeMutablePointers(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafeMutablePointer<τ_0_0>, UnsafeMutablePointer<τ_0_1>) throws -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(UnsafeMutablePointer<τ_0_0>, UnsafeMutablePointer<τ_0_1>)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafeMutablePointer",
+                      "printedName": "UnsafeMutablePointer<τ_0_0>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
+                        }
+                      ],
+                      "usr": "s:Sp"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafeMutablePointer",
+                      "printedName": "UnsafeMutablePointer<τ_0_1>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_1"
+                        }
+                      ],
+                      "usr": "s:Sp"
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13ManagedBufferC25withUnsafeMutablePointersyqd__qd__SpyxG_Spyq_GtKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Final",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Var",
+          "name": "header",
+          "printedName": "header",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13ManagedBufferC6headerxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent",
+                "Final"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13ManagedBufferC6headerxvs",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent",
+                "Final"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13ManagedBufferC6headerxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Final"
+          ],
+          "hasStorage": true
+        }
+      ],
+      "declKind": "Class",
+      "usr": "s:s13ManagedBufferC",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1>",
+      "isOpen": true,
+      "declAttributes": [
+        "FixedLayout"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "ManagedBufferPointer",
+      "printedName": "ManagedBufferPointer",
+      "children": [
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(bufferClass:minimumCapacity:makingHeaderWith:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ManagedBufferPointer",
+              "printedName": "ManagedBufferPointer<τ_0_0, τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:s20ManagedBufferPointerV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ExistentialMetatype",
+              "printedName": "AnyObject.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ProtocolComposition",
+                  "printedName": "AnyObject"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(AnyObject, (AnyObject) -> Int) throws -> τ_0_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(AnyObject, (AnyObject) -> Int)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "ProtocolComposition",
+                      "printedName": "AnyObject"
+                    },
+                    {
+                      "kind": "TypeFunc",
+                      "name": "Function",
+                      "printedName": "(AnyObject) -> Int",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Int",
+                          "printedName": "Int",
+                          "usr": "s:Si"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "ProtocolComposition",
+                          "printedName": "AnyObject"
+                        }
+                      ],
+                      "typeAttributes": [
+                        "noescape"
+                      ]
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s20ManagedBufferPointerV11bufferClass15minimumCapacity16makingHeaderWithAByxq_GyXlXp_SixyXl_SiyXlXEtKXEtKcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(unsafeBufferObject:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ManagedBufferPointer",
+              "printedName": "ManagedBufferPointer<τ_0_0, τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:s20ManagedBufferPointerV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ProtocolComposition",
+              "printedName": "AnyObject"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s20ManagedBufferPointerV06unsafeB6ObjectAByxq_GyXl_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "header",
+          "printedName": "header",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20ManagedBufferPointerV6headerxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20ManagedBufferPointerV6headerxvs",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20ManagedBufferPointerV6headerxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "buffer",
+          "printedName": "buffer",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ProtocolComposition",
+              "printedName": "AnyObject"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ProtocolComposition",
+                  "printedName": "AnyObject"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20ManagedBufferPointerV6bufferyXlvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20ManagedBufferPointerV6bufferyXlvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "capacity",
+          "printedName": "capacity",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20ManagedBufferPointerV8capacitySivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20ManagedBufferPointerV8capacitySivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeMutablePointerToHeader",
+          "printedName": "withUnsafeMutablePointerToHeader(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafeMutablePointer<τ_0_0>) throws -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutablePointer",
+                  "printedName": "UnsafeMutablePointer<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:Sp"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20ManagedBufferPointerV017withUnsafeMutableC8ToHeaderyqd__qd__SpyxGKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeMutablePointerToElements",
+          "printedName": "withUnsafeMutablePointerToElements(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafeMutablePointer<τ_0_1>) throws -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutablePointer",
+                  "printedName": "UnsafeMutablePointer<τ_0_1>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ],
+                  "usr": "s:Sp"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20ManagedBufferPointerV017withUnsafeMutableC10ToElementsyqd__qd__Spyq_GKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeMutablePointers",
+          "printedName": "withUnsafeMutablePointers(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafeMutablePointer<τ_0_0>, UnsafeMutablePointer<τ_0_1>) throws -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(UnsafeMutablePointer<τ_0_0>, UnsafeMutablePointer<τ_0_1>)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafeMutablePointer",
+                      "printedName": "UnsafeMutablePointer<τ_0_0>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
+                        }
+                      ],
+                      "usr": "s:Sp"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafeMutablePointer",
+                      "printedName": "UnsafeMutablePointer<τ_0_1>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_1"
+                        }
+                      ],
+                      "usr": "s:Sp"
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20ManagedBufferPointerV25withUnsafeMutablePointersyqd__qd__SpyxG_Spyq_GtKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "isUniqueReference",
+          "printedName": "isUniqueReference()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20ManagedBufferPointerV17isUniqueReferenceSbyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(bufferClass:minimumCapacity:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ManagedBufferPointer",
+              "printedName": "ManagedBufferPointer<τ_0_0, τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:s20ManagedBufferPointerV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ExistentialMetatype",
+              "printedName": "AnyObject.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ProtocolComposition",
+                  "printedName": "AnyObject"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s20ManagedBufferPointerV11bufferClass15minimumCapacityAByxq_GyXlXp_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1>",
+          "isInternal": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ManagedBufferPointer",
+              "printedName": "ManagedBufferPointer<τ_0_0, τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:s20ManagedBufferPointerV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ManagedBuffer",
+              "printedName": "ManagedBuffer<τ_0_0, τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:s13ManagedBufferC"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s20ManagedBufferPointerVyAByxq_Gs0aB0Cyxq_Gcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1>",
+          "isInternal": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ManagedBufferPointer",
+              "printedName": "ManagedBufferPointer<τ_0_0, τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:s20ManagedBufferPointerV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ManagedBufferPointer",
+              "printedName": "ManagedBufferPointer<τ_0_0, τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:s20ManagedBufferPointerV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20ManagedBufferPointerV2eeoiySbAByxq_G_ADtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "_nativeBuffer",
+          "printedName": "_nativeBuffer",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "BuiltinNativeObject",
+              "printedName": "Builtin.NativeObject"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinNativeObject",
+                  "printedName": "Builtin.NativeObject"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20ManagedBufferPointerV07_nativeB0Bovg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20ManagedBufferPointerV07_nativeB0Bovp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ManagedBufferPointer",
+              "printedName": "ManagedBufferPointer<τ_0_0, τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:s20ManagedBufferPointerV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ExistentialMetatype",
+              "printedName": "AnyObject.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ProtocolComposition",
+                  "printedName": "AnyObject"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Value"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s20ManagedBufferPointerVss05_HeapB7Header_RzrlEyAByxq_GyXlXp_5ValueQzSitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : _HeapBufferHeader_>",
+          "isInternal": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s20ManagedBufferPointerV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Equatable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "isKnownUniquelyReferenced",
+      "printedName": "isKnownUniquelyReferenced(_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s25isKnownUniquelyReferencedySbxzRlzClF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : AnyObject>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "isKnownUniquelyReferenced",
+      "printedName": "isKnownUniquelyReferenced(_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "Optional<τ_0_0>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "usr": "s:Sq"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s25isKnownUniquelyReferencedySbxSgzRlzClF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : AnyObject>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "LazyMapSequence",
+      "printedName": "LazyMapSequence",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_base",
+          "printedName": "_base",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15LazyMapSequenceV5_basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15LazyMapSequenceV5_basexvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_transform",
+          "printedName": "_transform",
+          "children": [
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Element) -> τ_0_1",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ]
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeFunc",
+                  "name": "Function",
+                  "printedName": "(τ_0_0.Element) -> τ_0_1",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    }
+                  ]
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15LazyMapSequenceV10_transformyq_7ElementQzcvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15LazyMapSequenceV10_transformyq_7ElementQzcvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "Iterator",
+          "printedName": "Iterator",
+          "children": [
+            {
+              "kind": "Var",
+              "name": "_base",
+              "printedName": "_base",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Iterator"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Iterator"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s15LazyMapSequenceV8IteratorV5_baseACQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s15LazyMapSequenceV8IteratorV5_baseACQzvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_transform",
+              "printedName": "_transform",
+              "children": [
+                {
+                  "kind": "TypeFunc",
+                  "name": "Function",
+                  "printedName": "(τ_0_0.Element) -> τ_0_1",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    }
+                  ]
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeFunc",
+                      "name": "Function",
+                      "printedName": "(τ_0_0.Element) -> τ_0_1",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_1"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "DependentMember",
+                          "printedName": "τ_0_0.Element"
+                        }
+                      ]
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s15LazyMapSequenceV8IteratorV10_transformyq_7ElementQzcvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s15LazyMapSequenceV8IteratorV10_transformyq_7ElementQzcvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 1,
+              "isLet": true,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "base",
+              "printedName": "base",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Iterator"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Iterator"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s15LazyMapSequenceV8IteratorV4baseACQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s15LazyMapSequenceV8IteratorV4baseACQzvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "next",
+              "printedName": "next()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_1>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s15LazyMapSequenceV8IteratorV4nextq_SgyF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s15LazyMapSequenceV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "Sequence"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "makeIterator",
+          "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Iterator",
+              "printedName": "LazyMapSequence<τ_0_0, τ_0_1>.Iterator",
+              "usr": "s:s15LazyMapSequenceV8IteratorV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15LazyMapSequenceV12makeIteratorAB0E0Vyxq__GyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "underestimatedCount",
+          "printedName": "underestimatedCount",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15LazyMapSequenceV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15LazyMapSequenceV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s15LazyMapSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "LazySequenceProtocol",
+        "Sequence"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "LazyMapCollection",
+      "printedName": "LazyMapCollection",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_base",
+          "printedName": "_base",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionV5_basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionV5_basexvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_transform",
+          "printedName": "_transform",
+          "children": [
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Element) -> τ_0_1",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ]
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeFunc",
+                  "name": "Function",
+                  "printedName": "(τ_0_0.Element) -> τ_0_1",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    }
+                  ]
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionV10_transformyq_7ElementQzcvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionV10_transformyq_7ElementQzcvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Function",
+          "name": "makeIterator",
+          "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Iterator",
+              "printedName": "LazyMapSequence<τ_0_0, τ_0_1>.Iterator",
+              "usr": "s:s15LazyMapSequenceV8IteratorV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17LazyMapCollectionV12makeIterators0aB8SequenceV0E0Vyxq__GyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "underestimatedCount",
+          "printedName": "underestimatedCount",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionV10startIndex0E0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionV10startIndex0E0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionV8endIndex0E0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionV8endIndex0E0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17LazyMapCollectionV5index5after5IndexQzAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17LazyMapCollectionV9formIndex5aftery0E0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s17LazyMapCollectionVyq_5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "LazyMapCollection",
+              "printedName": "LazyMapCollection<τ_0_0.SubSequence, τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.SubSequence"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:s17LazyMapCollectionV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s17LazyMapCollectionVyABy11SubSequenceQzq_GSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "indices",
+          "printedName": "indices",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Indices"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Indices"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionV7indices7IndicesQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionV7indices7IndicesQzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isEmpty",
+          "printedName": "isEmpty",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionV7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionV7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "count",
+          "printedName": "count",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "first",
+          "printedName": "first",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_1>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionV5firstq_Sgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionV5firstq_Sgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17LazyMapCollectionV5index_8offsetBy5IndexQzAF_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:limitedBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17LazyMapCollectionV5index_8offsetBy07limitedF05IndexQzSgAG_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(from:to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17LazyMapCollectionV8distance4from2toSi5IndexQz_AGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17LazyMapCollectionVsSKRzrlE5index6before5IndexQzAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17LazyMapCollectionVsSKRzrlE9formIndex6beforey0E0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "last",
+          "printedName": "last",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_1>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_1>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionVsSKRzrlE4lastq_Sgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : BidirectionalCollection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionVsSKRzrlE4lastq_Sgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s17LazyMapCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "LazyCollectionProtocol",
+        "Collection",
+        "LazySequenceProtocol",
+        "BidirectionalCollection",
+        "RandomAccessCollection"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "MemoryLayout",
+      "printedName": "MemoryLayout",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "size",
+          "printedName": "size",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12MemoryLayoutO4sizeSivgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12MemoryLayoutO4sizeSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "stride",
+          "printedName": "stride",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12MemoryLayoutO6strideSivgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12MemoryLayoutO6strideSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "alignment",
+          "printedName": "alignment",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12MemoryLayoutO9alignmentSivgZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12MemoryLayoutO9alignmentSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "size",
+          "printedName": "size(ofValue:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s12MemoryLayoutO4size7ofValueSix_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "stride",
+          "printedName": "stride(ofValue:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s12MemoryLayoutO6stride7ofValueSix_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "alignment",
+          "printedName": "alignment(ofValue:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s12MemoryLayoutO9alignment7ofValueSix_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "offset",
+          "printedName": "offset(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "PartialKeyPath",
+              "printedName": "PartialKeyPath<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s14PartialKeyPathC"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s12MemoryLayoutO6offset2ofSiSgs14PartialKeyPathCyxG_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s12MemoryLayoutO",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "Frozen"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "MutableCollection",
+      "printedName": "MutableCollection",
+      "children": [
+        {
+          "kind": "AssociatedType",
+          "name": "Element",
+          "printedName": "Element",
+          "declKind": "AssociatedType",
+          "usr": "s:SM7ElementQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Index",
+          "printedName": "Index",
+          "declKind": "AssociatedType",
+          "usr": "s:SM5IndexQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "declKind": "AssociatedType",
+          "usr": "s:SM11SubSequenceQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SMy7ElementQz5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : MutableCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.SubSequence"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SMy11SubSequenceQzSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : MutableCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Function",
+          "name": "partition",
+          "printedName": "partition(by:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Element) throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SM9partition2by5IndexQzSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : MutableCollection>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "swapAt",
+          "printedName": "swapAt(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SM6swapAtyy5IndexQz_ACtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : MutableCollection>",
+          "protocolReq": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "partition",
+          "printedName": "partition(by:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Element) throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SMsE9partition2by5IndexQzSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : MutableCollection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "partition",
+          "printedName": "partition(by:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Element) throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SMsSKRzrlE9partition2by5IndexSlQzSb7ElementSTQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0 : MutableCollection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "shuffle",
+          "printedName": "shuffle(using:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SMsSkRzrlE7shuffle5usingyqd__z_tSGRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : MutableCollection, τ_0_0 : RandomAccessCollection, τ_1_0 : RandomNumberGenerator>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "shuffle",
+          "printedName": "shuffle()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SMsSkRzrlE7shuffleyyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : MutableCollection, τ_0_0 : RandomAccessCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SMsEys5SliceVyxGSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : MutableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Function",
+          "name": "swapAt",
+          "printedName": "swapAt(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SMsE6swapAtyy5IndexQz_ACtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : MutableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.SubSequence"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SMsEy11SubSequenceQzqd__cSXRd__5BoundQyd__5IndexRtzluip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : MutableCollection, τ_1_0 : RangeExpression, τ_0_0.Index == τ_1_0.Bound>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.SubSequence"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnboundedRange_) -> ()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnboundedRange_",
+                  "printedName": "UnboundedRange_",
+                  "usr": "s:s15UnboundedRange_O"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SMsEy11SubSequenceQzys15UnboundedRange_OXEcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : MutableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Function",
+          "name": "reverse",
+          "printedName": "reverse()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SMsSKRzrlE7reverseyyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0 : MutableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "sort",
+          "printedName": "sort()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SMsSkRzSL7ElementSTRpzrlE4sortyyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : MutableCollection, τ_0_0 : RandomAccessCollection, τ_0_0.Element : Comparable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "sort",
+          "printedName": "sort(by:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Element, τ_0_0.Element) throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(τ_0_0.Element, τ_0_0.Element)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SMsSkRzrlE4sort2byySb7ElementSTQz_ADtKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : MutableCollection, τ_0_0 : RandomAccessCollection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
+        }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SM",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : Collection, τ_0_0.SubSequence : MutableCollection>",
+      "conformingProtocols": [
+        "Collection",
+        "Sequence"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "swap",
+      "printedName": "swap(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s4swapyyxz_xztlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "ObjectIdentifier",
+      "printedName": "ObjectIdentifier",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_value",
+          "printedName": "_value",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "BuiltinRawPointer",
+              "printedName": "Builtin.RawPointer"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinRawPointer",
+                  "printedName": "Builtin.RawPointer"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SO6_valueBpvg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SO6_valueBpvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ObjectIdentifier",
+              "printedName": "ObjectIdentifier",
+              "usr": "s:SO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ProtocolComposition",
+              "printedName": "AnyObject"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SOySOyXlcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ObjectIdentifier",
+              "printedName": "ObjectIdentifier",
+              "usr": "s:SO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ExistentialMetatype",
+              "printedName": "Any.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ProtocolComposition",
+                  "printedName": "Any"
+                }
+              ]
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SOySOypXpcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SO16debugDescriptionSSvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SO16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ObjectIdentifier",
+              "printedName": "ObjectIdentifier",
+              "usr": "s:SO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ObjectIdentifier",
+              "printedName": "ObjectIdentifier",
+              "usr": "s:SO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SO2eeoiySbSO_SOtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ObjectIdentifier",
+              "printedName": "ObjectIdentifier",
+              "usr": "s:SO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ObjectIdentifier",
+              "printedName": "ObjectIdentifier",
+              "usr": "s:SO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SO1loiySbSO_SOtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SO4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -71688,16 +77891,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SO4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SO9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -71709,10 +77914,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SO9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -71720,410 +77921,362 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SO9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SO9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:SO",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "CustomDebugStringConvertible",
+        "Equatable",
+        "Comparable",
+        "Hashable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Optional",
       "printedName": "Optional",
-      "declKind": "Enum",
-      "usr": "s:Sq",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Wrapped>",
-      "conformingProtocols": [
-        "ExpressibleByNilLiteral",
-        "Encodable",
-        "Decodable",
-        "CustomDebugStringConvertible",
-        "CustomReflectable",
-        "Equatable",
-        "Hashable",
-        "_ObjectiveCBridgeable"
-      ],
-      "declAttributes": [
-        "Frozen"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "none",
           "printedName": "none",
-          "declKind": "EnumElement",
-          "usr": "s:Sq4noneyxSgABmlF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
               "name": "GenericFunction",
-              "printedName": "<Wrapped> (Optional<Wrapped>.Type) -> Optional<Wrapped>",
+              "printedName": "<τ_0_0> (Optional<τ_0_0>.Type) -> Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Optional<Wrapped>",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Wrapped"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Optional<Wrapped>.Type)",
+                  "name": "Metatype",
+                  "printedName": "Optional<τ_0_0>.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "Optional<Wrapped>.Type",
+                      "name": "Optional",
+                      "printedName": "Optional<τ_0_0>",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Optional",
-                          "printedName": "Optional<Wrapped>",
-                          "usr": "s:Sq",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GenericTypeParam",
-                              "printedName": "Wrapped"
-                            }
-                          ]
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:Sq4noneyxSgABmlF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0
         },
         {
           "kind": "Var",
           "name": "some",
           "printedName": "some",
-          "declKind": "EnumElement",
-          "usr": "s:Sq4someyxSgxcABmlF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
               "name": "GenericFunction",
-              "printedName": "<Wrapped> (Optional<Wrapped>.Type) -> (Wrapped) -> Optional<Wrapped>",
+              "printedName": "<τ_0_0> (Optional<τ_0_0>.Type) -> (τ_0_0) -> Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeFunc",
                   "name": "Function",
-                  "printedName": "(Wrapped) -> Optional<Wrapped>",
+                  "printedName": "(τ_0_0) -> Optional<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
-                      "printedName": "Optional<Wrapped>",
-                      "usr": "s:Sq",
+                      "printedName": "Optional<τ_0_0>",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
-                          "printedName": "Wrapped"
+                          "printedName": "τ_0_0"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Wrapped)",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Wrapped"
-                        }
-                      ]
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
                     }
                   ]
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Optional<Wrapped>.Type)",
+                  "name": "Metatype",
+                  "printedName": "Optional<τ_0_0>.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "Optional<Wrapped>.Type",
+                      "name": "Optional",
+                      "printedName": "Optional<τ_0_0>",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Optional",
-                          "printedName": "Optional<Wrapped>",
-                          "usr": "s:Sq",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GenericTypeParam",
-                              "printedName": "Wrapped"
-                            }
-                          ]
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:Sq4someyxSgxcABmlF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SqyxSgxcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Wrapped>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Optional<Wrapped>",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Wrapped"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Wrapped"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SqyxSgxcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:Sq3mapyqd__Sgqd__xKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Wrapped, U>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "U?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "U"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Wrapped) throws -> U",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> τ_1_0",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "U"
+                  "printedName": "τ_1_0"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Wrapped)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Wrapped"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sq3mapyqd__Sgqd__xKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "flatMap",
           "printedName": "flatMap(_:)",
-          "declKind": "Func",
-          "usr": "s:Sq7flatMapyqd__SgABxKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Wrapped, U>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "U?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "U"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Wrapped) throws -> U?",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> Optional<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "U?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<τ_1_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "U"
+                      "printedName": "τ_1_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Wrapped)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Wrapped"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sq7flatMapyqd__SgABxKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(nilLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Sq10nilLiteralxSgyt_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Wrapped>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Optional<Wrapped>",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Wrapped"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sq10nilLiteralxSgyt_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "unsafelyUnwrapped",
           "printedName": "unsafelyUnwrapped",
-          "declKind": "Var",
-          "usr": "s:Sq17unsafelyUnwrappedxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Wrapped"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sq17unsafelyUnwrappedxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Wrapped>",
-              "declAttributes": [
-                "Inline"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Wrapped"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sq17unsafelyUnwrappedxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "declAttributes": [
+                "Inline"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sq17unsafelyUnwrappedxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:SqsSERzlE6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Wrapped where Wrapped : Encodable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -72136,34 +78289,30 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SqsSERzlE6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:SqsSeRzlE4fromxSgs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Wrapped where Wrapped : Decodable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Optional<Wrapped>",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Wrapped"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -72171,16 +78320,17 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SqsSeRzlE4fromxSgs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable>",
+          "throwing": true
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Sq16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -72192,11 +78342,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sq16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Wrapped>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -72204,18 +78349,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sq16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sq16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Sq12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -72227,11 +78375,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sq12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Wrapped>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -72239,22 +78382,68 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sq12customMirrors0B0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sq12customMirrors0B0Vvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SqsSQRzlE2eeoiySbxSg_ABtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Equatable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SqsSHRzlE4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Wrapped where Wrapped : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -72267,16 +78456,19 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SqsSHRzlE4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SqsSHRzlE9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -72288,11 +78480,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SqsSHRzlE9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Wrapped where Wrapped : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -72300,137 +78487,482 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SqsSHRzlE9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+              "implicit": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SqsSHRzlE9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Function",
+          "name": "~=",
+          "printedName": "~=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "_OptionalNilComparisonType",
+              "printedName": "_OptionalNilComparisonType",
+              "usr": "s:s26_OptionalNilComparisonTypeV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sq2teoiySbs26_OptionalNilComparisonTypeV_xSgtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "_OptionalNilComparisonType",
+              "printedName": "_OptionalNilComparisonType",
+              "usr": "s:s26_OptionalNilComparisonTypeV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sq2eeoiySbxSg_s26_OptionalNilComparisonTypeVtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "!=",
+          "printedName": "!=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "_OptionalNilComparisonType",
+              "printedName": "_OptionalNilComparisonType",
+              "usr": "s:s26_OptionalNilComparisonTypeV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sq2neoiySbxSg_s26_OptionalNilComparisonTypeVtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "_OptionalNilComparisonType",
+              "printedName": "_OptionalNilComparisonType",
+              "usr": "s:s26_OptionalNilComparisonTypeV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sq2eeoiySbs26_OptionalNilComparisonTypeV_xSgtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "!=",
+          "printedName": "!=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "_OptionalNilComparisonType",
+              "printedName": "_OptionalNilComparisonType",
+              "usr": "s:s26_OptionalNilComparisonTypeV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sq2neoiySbs26_OptionalNilComparisonTypeV_xSgtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:Sq",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "Frozen"
+      ],
+      "conformingProtocols": [
+        "ExpressibleByNilLiteral",
+        "Encodable",
+        "Decodable",
+        "CustomDebugStringConvertible",
+        "CustomReflectable",
+        "Equatable",
+        "Hashable",
+        "_ObjectiveCBridgeable"
       ]
     },
     {
+      "kind": "Function",
+      "name": "??",
+      "printedName": "??(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "Optional<τ_0_0>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "usr": "s:Sq"
+        },
+        {
+          "kind": "TypeFunc",
+          "name": "Function",
+          "printedName": "() throws -> τ_0_0",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "typeAttributes": [
+            "noescape"
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2qqoiyxxSg_xyKXKtKlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "Rethrows",
+        "Transparent"
+      ],
+      "throwing": true
+    },
+    {
+      "kind": "Function",
+      "name": "??",
+      "printedName": "??(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "Optional<τ_0_0>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "usr": "s:Sq"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "Optional<τ_0_0>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "usr": "s:Sq"
+        },
+        {
+          "kind": "TypeFunc",
+          "name": "Function",
+          "printedName": "() throws -> Optional<τ_0_0>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "typeAttributes": [
+            "noescape"
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2qqoiyxSgAB_AByKXKtKlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "Rethrows",
+        "Transparent"
+      ],
+      "throwing": true
+    },
+    {
       "kind": "TypeDecl",
       "name": "OptionSet",
       "printedName": "OptionSet",
-      "declKind": "Protocol",
-      "usr": "s:s9OptionSetP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : RawRepresentable, Self : SetAlgebra>",
-      "conformingProtocols": [
-        "SetAlgebra",
-        "RawRepresentable",
-        "Equatable",
-        "ExpressibleByArrayLiteral"
-      ],
       "children": [
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(rawValue:)",
-          "declKind": "Constructor",
-          "usr": "s:s9OptionSetP8rawValuex03RawD0Qz_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet>",
+          "kind": "AssociatedType",
+          "name": "Element",
+          "printedName": "Element",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:s9OptionSetP7ElementQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(rawValue:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.RawValue"
+              "printedName": "τ_0_0.RawValue"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s9OptionSetP8rawValuex03RawD0Qz_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : OptionSet>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "union",
           "printedName": "union(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPsE5unionyxxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPsE5unionyxxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : OptionSet>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "intersection",
           "printedName": "intersection(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPsE12intersectionyxxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPsE12intersectionyxxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : OptionSet>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "symmetricDifference",
           "printedName": "symmetricDifference(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPsE19symmetricDifferenceyxxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPsE19symmetricDifferenceyxxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : OptionSet>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPs7ElementQzRszrlE8containsySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet, Self == Self.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -72441,29 +78973,26 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPs7ElementQzRszrlE8containsySbxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : OptionSet, τ_0_0 == τ_0_0.Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPs7ElementQzRszrlE6insertySb8inserted_x17memberAfterInserttxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet, Self == Self.Element>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(inserted: Bool, memberAfterInsert: Self.Element)",
+              "printedName": "(inserted: Bool, memberAfterInsert: τ_0_0.Element)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -72474,120 +79003,117 @@
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
               ]
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPs7ElementQzRszrlE6insertySb8inserted_x17memberAfterInserttxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : OptionSet, τ_0_0 == τ_0_0.Element>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "remove",
           "printedName": "remove(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPs7ElementQzRszrlE6removeyxSgxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet, Self == Self.Element>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPs7ElementQzRszrlE6removeyxSgxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : OptionSet, τ_0_0 == τ_0_0.Element>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "update",
           "printedName": "update(with:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPs7ElementQzRszrlE6update4withxSgx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet, Self == Self.Element>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPs7ElementQzRszrlE6update4withxSgx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : OptionSet, τ_0_0 == τ_0_0.Element>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s9OptionSetPss17FixedWidthInteger8RawValueRpzrlExycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet, Self.RawValue : FixedWidthInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s9OptionSetPss17FixedWidthInteger8RawValueRpzrlExycfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : OptionSet, τ_0_0.RawValue : FixedWidthInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formUnion",
           "printedName": "formUnion(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPss17FixedWidthInteger8RawValueRpzrlE9formUnionyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet, Self.RawValue : FixedWidthInteger>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -72597,23 +79123,22 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPss17FixedWidthInteger8RawValueRpzrlE9formUnionyyxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : OptionSet, τ_0_0.RawValue : FixedWidthInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "formIntersection",
           "printedName": "formIntersection(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPss17FixedWidthInteger8RawValueRpzrlE16formIntersectionyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet, Self.RawValue : FixedWidthInteger>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -72623,23 +79148,22 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPss17FixedWidthInteger8RawValueRpzrlE16formIntersectionyyxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : OptionSet, τ_0_0.RawValue : FixedWidthInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "formSymmetricDifference",
           "printedName": "formSymmetricDifference(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPss17FixedWidthInteger8RawValueRpzrlE23formSymmetricDifferenceyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet, Self.RawValue : FixedWidthInteger>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -72649,31 +79173,39 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPss17FixedWidthInteger8RawValueRpzrlE23formSymmetricDifferenceyyxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : OptionSet, τ_0_0.RawValue : FixedWidthInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s9OptionSetP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : RawRepresentable, τ_0_0 : SetAlgebra>",
+      "conformingProtocols": [
+        "SetAlgebra",
+        "RawRepresentable",
+        "Equatable",
+        "ExpressibleByArrayLiteral"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "TextOutputStream",
       "printedName": "TextOutputStream",
-      "declKind": "Protocol",
-      "usr": "s:s16TextOutputStreamP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Function",
           "name": "write",
           "printedName": "write(_:)",
-          "declKind": "Func",
-          "usr": "s:s16TextOutputStreamP5writeyySSF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : TextOutputStream>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -72686,28 +79218,28 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16TextOutputStreamP5writeyySSF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : TextOutputStream>",
+          "protocolReq": true,
+          "mutating": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s16TextOutputStreamP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "TextOutputStreamable",
       "printedName": "TextOutputStreamable",
-      "declKind": "Protocol",
-      "usr": "s:s20TextOutputStreamableP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Function",
           "name": "write",
           "printedName": "write(to:)",
-          "declKind": "Func",
-          "usr": "s:s20TextOutputStreamableP5write2toyqd__z_ts0aB6StreamRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Target where Self : TextOutputStreamable, Target : TextOutputStream>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -72717,29 +79249,29 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Target"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s20TextOutputStreamableP5write2toyqd__z_ts0aB6StreamRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : TextOutputStreamable, τ_1_0 : TextOutputStream>",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s20TextOutputStreamableP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "CustomStringConvertible",
       "printedName": "CustomStringConvertible",
-      "declKind": "Protocol",
-      "usr": "s:s23CustomStringConvertibleP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:s23CustomStringConvertibleP11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -72751,11 +79283,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s23CustomStringConvertibleP11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CustomStringConvertible>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -72763,47 +79290,45 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s23CustomStringConvertibleP11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : CustomStringConvertible>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s23CustomStringConvertibleP11descriptionSSvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s23CustomStringConvertibleP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "LosslessStringConvertible",
       "printedName": "LosslessStringConvertible",
-      "declKind": "Protocol",
-      "usr": "s:s25LosslessStringConvertibleP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : CustomStringConvertible>",
-      "conformingProtocols": [
-        "CustomStringConvertible"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s25LosslessStringConvertiblePyxSgSScfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LosslessStringConvertible>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -72811,27 +79336,31 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s25LosslessStringConvertiblePyxSgSScfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : LosslessStringConvertible>",
+          "protocolReq": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s25LosslessStringConvertibleP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : CustomStringConvertible>",
+      "conformingProtocols": [
+        "CustomStringConvertible"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "CustomDebugStringConvertible",
       "printedName": "CustomDebugStringConvertible",
-      "declKind": "Protocol",
-      "usr": "s:s28CustomDebugStringConvertibleP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s28CustomDebugStringConvertibleP16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -72843,11 +79372,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s28CustomDebugStringConvertibleP16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CustomDebugStringConvertible>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -72855,38 +79379,94 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s28CustomDebugStringConvertibleP16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : CustomDebugStringConvertible>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s28CustomDebugStringConvertibleP16debugDescriptionSSvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s28CustomDebugStringConvertibleP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "Never",
       "printedName": "Never",
-      "declKind": "Enum",
-      "usr": "s:s5NeverO",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Error",
-        "Equatable",
-        "Comparable",
-        "Hashable"
-      ],
-      "declAttributes": [
-        "Frozen"
-      ],
       "children": [
         {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Never",
+              "printedName": "Never",
+              "usr": "s:s5NeverO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Never",
+              "printedName": "Never",
+              "usr": "s:s5NeverO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5NeverO2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "implicit": true,
+          "declAttributes": [
+            "Infix"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Never",
+              "printedName": "Never",
+              "usr": "s:s5NeverO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Never",
+              "printedName": "Never",
+              "usr": "s:s5NeverO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5NeverO1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true
+        },
+        {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s5NeverO9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -72898,10 +79478,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5NeverO9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -72909,18 +79485,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5NeverO9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5NeverO9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s5NeverO4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -72933,635 +79513,1275 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5NeverO4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "implicit": true
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s5NeverO",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Frozen"
+      ],
+      "conformingProtocols": [
+        "Error",
+        "Equatable",
+        "Comparable",
+        "Hashable"
       ]
     },
     {
-      "kind": "TypeAlias",
-      "name": "Void",
-      "printedName": "Void",
-      "declKind": "TypeAlias",
-      "usr": "s:s4Voida",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Void",
-          "printedName": "()"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "Float32",
-      "printedName": "Float32",
-      "declKind": "TypeAlias",
-      "usr": "s:s7Float32a",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Float",
-          "printedName": "Float",
-          "usr": "s:Sf"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "Float64",
-      "printedName": "Float64",
-      "declKind": "TypeAlias",
-      "usr": "s:s7Float64a",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Double",
-          "printedName": "Double",
-          "usr": "s:Sd"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "IntegerLiteralType",
-      "printedName": "IntegerLiteralType",
-      "declKind": "TypeAlias",
-      "usr": "s:s18IntegerLiteralTypea",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Int",
-          "printedName": "Int",
-          "usr": "s:Si"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "FloatLiteralType",
-      "printedName": "FloatLiteralType",
-      "declKind": "TypeAlias",
-      "usr": "s:s16FloatLiteralTypea",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Double",
-          "printedName": "Double",
-          "usr": "s:Sd"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "BooleanLiteralType",
-      "printedName": "BooleanLiteralType",
-      "declKind": "TypeAlias",
-      "usr": "s:s18BooleanLiteralTypea",
-      "location": "",
-      "moduleName": "Swift",
+      "kind": "Function",
+      "name": "~=",
+      "printedName": "~=(_:_:)",
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Bool",
           "printedName": "Bool",
           "usr": "s:Sb"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "UnicodeScalarType",
-      "printedName": "UnicodeScalarType",
-      "declKind": "TypeAlias",
-      "usr": "s:s17UnicodeScalarTypea",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
+        },
         {
           "kind": "TypeNominal",
-          "name": "String",
-          "printedName": "String",
-          "usr": "s:SS"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "ExtendedGraphemeClusterType",
-      "printedName": "ExtendedGraphemeClusterType",
-      "declKind": "TypeAlias",
-      "usr": "s:s27ExtendedGraphemeClusterTypea",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
         {
           "kind": "TypeNominal",
-          "name": "String",
-          "printedName": "String",
-          "usr": "s:SS"
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2teoiySbx_xtSQRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Equatable>",
+      "declAttributes": [
+        "Transparent"
       ]
     },
     {
-      "kind": "TypeAlias",
-      "name": "StringLiteralType",
-      "printedName": "StringLiteralType",
-      "declKind": "TypeAlias",
-      "usr": "s:s17StringLiteralTypea",
-      "location": "",
+      "kind": "OperatorDecl",
+      "name": "++",
+      "printedName": "++",
+      "declKind": "PostfixOperator",
       "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "String",
-          "printedName": "String",
-          "usr": "s:SS"
-        }
+      "declAttributes": [
+        "Postfix"
       ]
     },
     {
-      "kind": "TypeAlias",
-      "name": "AnyObject",
-      "printedName": "AnyObject",
-      "declKind": "TypeAlias",
-      "usr": "s:s9AnyObjecta",
-      "location": "",
+      "kind": "OperatorDecl",
+      "name": "--",
+      "printedName": "--",
+      "declKind": "PostfixOperator",
       "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNameAlias",
-          "name": "AnyObject",
-          "printedName": "AnyObject",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ProtocolComposition",
-              "printedName": "AnyObject"
-            }
-          ]
-        }
+      "declAttributes": [
+        "Postfix"
       ]
     },
     {
-      "kind": "TypeAlias",
-      "name": "AnyClass",
-      "printedName": "AnyClass",
-      "declKind": "TypeAlias",
-      "usr": "s:s8AnyClassa",
-      "location": "",
+      "kind": "OperatorDecl",
+      "name": "...",
+      "printedName": "...",
+      "declKind": "PostfixOperator",
       "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ExistentialMetatype",
-          "printedName": "AnyObject.Type",
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "AnyObject",
-              "printedName": "AnyObject",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "ProtocolComposition",
-                  "printedName": "AnyObject"
-                }
-              ]
-            }
-          ]
-        }
+      "declAttributes": [
+        "Postfix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "++",
+      "printedName": "++",
+      "declKind": "PrefixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Prefix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "--",
+      "printedName": "--",
+      "declKind": "PrefixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Prefix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "!",
+      "printedName": "!",
+      "declKind": "PrefixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Prefix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "~",
+      "printedName": "~",
+      "declKind": "PrefixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Prefix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "+",
+      "printedName": "+",
+      "declKind": "PrefixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Prefix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "-",
+      "printedName": "-",
+      "declKind": "PrefixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Prefix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "...",
+      "printedName": "...",
+      "declKind": "PrefixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Prefix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "..<",
+      "printedName": "..<",
+      "declKind": "PrefixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Prefix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "<<",
+      "printedName": "<<",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&<<",
+      "printedName": "&<<",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": ">>",
+      "printedName": ">>",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&>>",
+      "printedName": "&>>",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "*",
+      "printedName": "*",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&*",
+      "printedName": "&*",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "\/",
+      "printedName": "\/",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "%",
+      "printedName": "%",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&",
+      "printedName": "&",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "+",
+      "printedName": "+",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&+",
+      "printedName": "&+",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "-",
+      "printedName": "-",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&-",
+      "printedName": "&-",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "|",
+      "printedName": "|",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "^",
+      "printedName": "^",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "...",
+      "printedName": "...",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "..<",
+      "printedName": "..<",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "??",
+      "printedName": "??",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "<",
+      "printedName": "<",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "<=",
+      "printedName": "<=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": ">",
+      "printedName": ">",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": ">=",
+      "printedName": ">=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "==",
+      "printedName": "==",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "!=",
+      "printedName": "!=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "===",
+      "printedName": "===",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "!==",
+      "printedName": "!==",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "~=",
+      "printedName": "~=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&&",
+      "printedName": "&&",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "||",
+      "printedName": "||",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "*=",
+      "printedName": "*=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&*=",
+      "printedName": "&*=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "\/=",
+      "printedName": "\/=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "%=",
+      "printedName": "%=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "+=",
+      "printedName": "+=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&+=",
+      "printedName": "&+=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "-=",
+      "printedName": "-=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&-=",
+      "printedName": "&-=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "<<=",
+      "printedName": "<<=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&<<=",
+      "printedName": "&<<=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": ">>=",
+      "printedName": ">>=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&>>=",
+      "printedName": "&>>=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&=",
+      "printedName": "&=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "^=",
+      "printedName": "^=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "|=",
+      "printedName": "|=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "~>",
+      "printedName": "~>",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "LazyPrefixWhileSequence",
       "printedName": "LazyPrefixWhileSequence",
-      "declKind": "Struct",
-      "usr": "s:s23LazyPrefixWhileSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Sequence>",
-      "conformingProtocols": [
-        "Sequence",
-        "LazySequenceProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s23LazyPrefixWhileSequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
+          "kind": "Var",
+          "name": "_base",
+          "printedName": "_base",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element"
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s23LazyPrefixWhileSequenceV5_basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s23LazyPrefixWhileSequenceV5_basexvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_predicate",
+          "printedName": "_predicate",
+          "children": [
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Element) -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ]
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeFunc",
+                  "name": "Function",
+                  "printedName": "(τ_0_0.Element) -> Bool",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    }
+                  ]
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s23LazyPrefixWhileSequenceV10_predicateySb7ElementQzcvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s23LazyPrefixWhileSequenceV10_predicateySb7ElementQzcvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "conformingProtocols": [
-            "IteratorProtocol",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV7Elementa",
-              "location": "",
+              "kind": "Var",
+              "name": "_predicateHasFailed",
+              "printedName": "_predicateHasFailed",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV19_predicateHasFailedSbvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV19_predicateHasFailedSbvp",
               "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
+              "isInternal": true,
+              "declAttributes": [
+                "HasInitialValue",
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_base",
+              "printedName": "_base",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Base.Element"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "next",
-              "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV4next7ElementQzSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
+                  "printedName": "τ_0_0.Iterator"
+                },
                 {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "LazyPrefixWhileSequence<Base>.Iterator.Element?",
-                  "usr": "s:Sq",
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "LazyPrefixWhileSequence<Base>.Iterator.Element",
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Iterator"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV5_baseACQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV5_baseACQzvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 1,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_predicate",
+              "printedName": "_predicate",
+              "children": [
+                {
+                  "kind": "TypeFunc",
+                  "name": "Function",
+                  "printedName": "(τ_0_0.Element) -> Bool",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    }
+                  ]
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeFunc",
+                      "name": "Function",
+                      "printedName": "(τ_0_0.Element) -> Bool",
                       "children": [
                         {
                           "kind": "TypeNominal",
+                          "name": "Bool",
+                          "printedName": "Bool",
+                          "usr": "s:Sb"
+                        },
+                        {
+                          "kind": "TypeNominal",
                           "name": "DependentMember",
                           "printedName": "τ_0_0.Element"
                         }
                       ]
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV10_predicateySb7ElementQzcvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV10_predicateySb7ElementQzcvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 2,
+              "isLet": true,
+              "hasStorage": true
             },
             {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorVACa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
+              "kind": "Function",
+              "name": "next",
+              "printedName": "next()",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "LazyPrefixWhileSequence<Base>.Iterator",
-                  "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV03SubD0a",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnySequence",
-                  "printedName": "AnySequence<Base.Element>",
-                  "usr": "s:s11AnySequenceV",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_0.Element>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Base.Element"
+                      "printedName": "τ_0_0.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV4next7ElementQzSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s23LazyPrefixWhileSequenceV03SubD0a",
-          "location": "",
+          ],
+          "declKind": "Struct",
+          "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV",
           "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnySequence",
-              "printedName": "AnySequence<Base.Element>",
-              "usr": "s:s11AnySequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Element"
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "Sequence"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s23LazyPrefixWhileSequenceV12makeIteratorAB0F0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Iterator",
-              "printedName": "LazyPrefixWhileSequence<Base>.Iterator",
+              "printedName": "LazyPrefixWhileSequence<τ_0_0>.Iterator",
               "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Elements",
-          "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s23LazyPrefixWhileSequenceV8Elementsa",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s23LazyPrefixWhileSequenceV12makeIteratorAB0F0Vyx_GyF",
           "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyPrefixWhileSequence",
-              "printedName": "LazyPrefixWhileSequence<Base>",
-              "usr": "s:s23LazyPrefixWhileSequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s23LazyPrefixWhileSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "LazySequenceProtocol"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "LazyPrefixWhileCollection",
       "printedName": "LazyPrefixWhileCollection",
-      "declKind": "Struct",
-      "usr": "s:s25LazyPrefixWhileCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Collection>",
-      "conformingProtocols": [
-        "Sequence",
-        "Collection",
-        "BidirectionalCollection",
-        "LazyCollectionProtocol",
-        "LazySequenceProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s25LazyPrefixWhileCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
+          "kind": "Var",
+          "name": "_base",
+          "printedName": "_base",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s25LazyPrefixWhileCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
             {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<LazyPrefixWhileCollection<Base>>",
-              "usr": "s:s5SliceV",
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "LazyPrefixWhileCollection",
-                  "printedName": "LazyPrefixWhileCollection<Base>",
-                  "usr": "s:s25LazyPrefixWhileCollectionV",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25LazyPrefixWhileCollectionV5_basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s25LazyPrefixWhileCollectionV5_basexvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_predicate",
+          "printedName": "_predicate",
+          "children": [
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Element) -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ]
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeFunc",
+                  "name": "Function",
+                  "printedName": "(τ_0_0.Element) -> Bool",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Base"
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
                     }
                   ]
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25LazyPrefixWhileCollectionV10_predicateySb7ElementQzcvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s25LazyPrefixWhileCollectionV8Iteratora",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s25LazyPrefixWhileCollectionV10_predicateySb7ElementQzcvp",
           "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Iterator",
-              "printedName": "LazyPrefixWhileSequence<Base>.Iterator",
-              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV"
-            }
-          ]
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s25LazyPrefixWhileCollectionV12makeIterators0abC8SequenceV0F0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
+              "kind": "TypeNominal",
               "name": "Iterator",
-              "printedName": "LazyPrefixWhileCollection<Base>.Iterator",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "LazyPrefixWhileSequence<τ_0_0>.Iterator",
-                  "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV"
-                }
-              ]
+              "printedName": "LazyPrefixWhileSequence<τ_0_0>.Iterator",
+              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25LazyPrefixWhileCollectionV12makeIterators0abC8SequenceV0F0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "Struct",
-          "usr": "s:s25LazyPrefixWhileCollectionV5IndexV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "conformingProtocols": [
-            "Comparable",
-            "Equatable",
-            "Hashable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
+              "kind": "Var",
+              "name": "_value",
+              "printedName": "_value",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_IndexRepresentation",
+                  "printedName": "LazyPrefixWhileCollection<τ_0_0>._IndexRepresentation",
+                  "usr": "s:s25LazyPrefixWhileCollectionV20_IndexRepresentationO"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_IndexRepresentation",
+                      "printedName": "LazyPrefixWhileCollection<τ_0_0>._IndexRepresentation",
+                      "usr": "s:s25LazyPrefixWhileCollectionV20_IndexRepresentationO"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s25LazyPrefixWhileCollectionV5IndexV6_valueAB01_E14RepresentationOyx_Gvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s25LazyPrefixWhileCollectionV5IndexV6_valueAB01_E14RepresentationOyx_Gvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "isLet": true,
+              "hasStorage": true
+            },
+            {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s25LazyPrefixWhileCollectionV5IndexVyADyx_GACQzcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "LazyPrefixWhileCollection<Base>.Index",
+                  "printedName": "LazyPrefixWhileCollection<τ_0_0>.Index",
                   "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Base.Index"
+                  "printedName": "τ_0_0.Index"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s25LazyPrefixWhileCollectionV5IndexVyADyx_GACQzcfc",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "isInternal": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(endOf:)",
-              "declKind": "Constructor",
-              "usr": "s:s25LazyPrefixWhileCollectionV5IndexV5endOfADyx_Gx_tcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "LazyPrefixWhileCollection<Base>.Index",
+                  "printedName": "LazyPrefixWhileCollection<τ_0_0>.Index",
                   "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Base"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s25LazyPrefixWhileCollectionV5IndexV5endOfADyx_Gx_tcfc",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "isInternal": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "LazyPrefixWhileCollection<τ_0_0>.Index",
+                  "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "LazyPrefixWhileCollection<τ_0_0>.Index",
+                  "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s25LazyPrefixWhileCollectionV5IndexV2eeoiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "LazyPrefixWhileCollection<τ_0_0>.Index",
+                  "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "LazyPrefixWhileCollection<τ_0_0>.Index",
+                  "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s25LazyPrefixWhileCollectionV5IndexV1loiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s25LazyPrefixWhileCollectionV5IndexVsSHACRpzrlE4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection, Base.Index : Hashable>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -73574,16 +80794,19 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s25LazyPrefixWhileCollectionV5IndexVsSHACRpzrlE4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Index : Hashable>",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s25LazyPrefixWhileCollectionV5IndexVsSHACRpzrlE9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -73595,11 +80818,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s25LazyPrefixWhileCollectionV5IndexVsSHACRpzrlE9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Base where Base : Collection, Base.Index : Hashable>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -73607,213 +80825,202 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s25LazyPrefixWhileCollectionV5IndexVsSHACRpzrlE9hashValueSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Index : Hashable>",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s25LazyPrefixWhileCollectionV5IndexVsSHACRpzrlE9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s25LazyPrefixWhileCollectionV5IndexV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "Comparable",
+            "Equatable",
+            "Hashable"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s25LazyPrefixWhileCollectionV10startIndexAB0F0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "LazyPrefixWhileCollection<Base>.Index",
+              "printedName": "LazyPrefixWhileCollection<τ_0_0>.Index",
               "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s25LazyPrefixWhileCollectionV10startIndexAB0F0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "LazyPrefixWhileCollection<Base>.Index",
+                  "printedName": "LazyPrefixWhileCollection<τ_0_0>.Index",
                   "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25LazyPrefixWhileCollectionV10startIndexAB0F0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s25LazyPrefixWhileCollectionV10startIndexAB0F0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s25LazyPrefixWhileCollectionV8endIndexAB0F0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "LazyPrefixWhileCollection<Base>.Index",
+              "printedName": "LazyPrefixWhileCollection<τ_0_0>.Index",
               "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s25LazyPrefixWhileCollectionV8endIndexAB0F0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "LazyPrefixWhileCollection<Base>.Index",
+                  "printedName": "LazyPrefixWhileCollection<τ_0_0>.Index",
                   "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25LazyPrefixWhileCollectionV8endIndexAB0F0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s25LazyPrefixWhileCollectionV8endIndexAB0F0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s25LazyPrefixWhileCollectionV5index5afterAB5IndexVyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "LazyPrefixWhileCollection<Base>.Index",
+              "printedName": "LazyPrefixWhileCollection<τ_0_0>.Index",
               "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "LazyPrefixWhileCollection<Base>.Index",
+              "printedName": "LazyPrefixWhileCollection<τ_0_0>.Index",
               "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25LazyPrefixWhileCollectionV5index5afterAB5IndexVyx_GAG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s25LazyPrefixWhileCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "DefaultIndices",
-              "printedName": "DefaultIndices<LazyPrefixWhileCollection<Base>>",
-              "usr": "s:SI",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "LazyPrefixWhileCollection",
-                  "printedName": "LazyPrefixWhileCollection<Base>",
-                  "usr": "s:s25LazyPrefixWhileCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Base"
-                    }
-                  ]
-                }
-              ]
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "LazyPrefixWhileCollection<τ_0_0>.Index",
+              "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s25LazyPrefixWhileCollectionVy7ElementQzAB5IndexVyx_Gcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s25LazyPrefixWhileCollectionVsSKRzrlE5index6beforeAB5IndexVyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "LazyPrefixWhileCollection<Base>.Index",
+              "printedName": "LazyPrefixWhileCollection<τ_0_0>.Index",
               "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "LazyPrefixWhileCollection<Base>.Index",
+              "printedName": "LazyPrefixWhileCollection<τ_0_0>.Index",
               "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Elements",
-          "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s25LazyPrefixWhileCollectionV8Elementsa",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s25LazyPrefixWhileCollectionVsSKRzrlE5index6beforeAB5IndexVyx_GAG_tF",
           "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyPrefixWhileCollection",
-              "printedName": "LazyPrefixWhileCollection<Base>",
-              "usr": "s:s25LazyPrefixWhileCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s25LazyPrefixWhileCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "Collection",
+        "BidirectionalCollection",
+        "LazyCollectionProtocol",
+        "LazySequenceProtocol"
       ]
     },
     {
       "kind": "Function",
       "name": "print",
       "printedName": "print(_:separator:terminator:)",
-      "declKind": "Func",
-      "usr": "s:s5print_9separator10terminatoryypd_S2StF",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Inline"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -73823,15 +81030,15 @@
         {
           "kind": "TypeNominal",
           "name": "Array",
-          "printedName": "[Any]",
-          "usr": "s:Sa",
+          "printedName": "Array<Any>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ProtocolComposition",
               "printedName": "Any"
             }
-          ]
+          ],
+          "usr": "s:Sa"
         },
         {
           "kind": "TypeNominal",
@@ -73847,19 +81054,15 @@
           "hasDefaultArg": true,
           "usr": "s:SS"
         }
-      ]
+      ],
+      "declKind": "Func",
+      "usr": "s:s5print_9separator10terminatoryypd_S2StF",
+      "moduleName": "Swift"
     },
     {
       "kind": "Function",
       "name": "debugPrint",
       "printedName": "debugPrint(_:separator:terminator:)",
-      "declKind": "Func",
-      "usr": "s:s10debugPrint_9separator10terminatoryypd_S2StF",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Inline"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -73869,15 +81072,15 @@
         {
           "kind": "TypeNominal",
           "name": "Array",
-          "printedName": "[Any]",
-          "usr": "s:Sa",
+          "printedName": "Array<Any>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ProtocolComposition",
               "printedName": "Any"
             }
-          ]
+          ],
+          "usr": "s:Sa"
         },
         {
           "kind": "TypeNominal",
@@ -73893,21 +81096,15 @@
           "hasDefaultArg": true,
           "usr": "s:SS"
         }
-      ]
+      ],
+      "declKind": "Func",
+      "usr": "s:s10debugPrint_9separator10terminatoryypd_S2StF",
+      "moduleName": "Swift"
     },
     {
       "kind": "Function",
       "name": "print",
       "printedName": "print(_:separator:terminator:to:)",
-      "declKind": "Func",
-      "usr": "s:s5print_9separator10terminator2toyypd_S2Sxzts16TextOutputStreamRzlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Target where Target : TextOutputStream>",
-      "declAttributes": [
-        "Inline",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -73917,15 +81114,15 @@
         {
           "kind": "TypeNominal",
           "name": "Array",
-          "printedName": "[Any]",
-          "usr": "s:Sa",
+          "printedName": "Array<Any>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ProtocolComposition",
               "printedName": "Any"
             }
-          ]
+          ],
+          "usr": "s:Sa"
         },
         {
           "kind": "TypeNominal",
@@ -73944,23 +81141,18 @@
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "Target"
+          "printedName": "τ_0_0"
         }
-      ]
+      ],
+      "declKind": "Func",
+      "usr": "s:s5print_9separator10terminator2toyypd_S2Sxzts16TextOutputStreamRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : TextOutputStream>"
     },
     {
       "kind": "Function",
       "name": "debugPrint",
       "printedName": "debugPrint(_:separator:terminator:to:)",
-      "declKind": "Func",
-      "usr": "s:s10debugPrint_9separator10terminator2toyypd_S2Sxzts16TextOutputStreamRzlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Target where Target : TextOutputStream>",
-      "declAttributes": [
-        "Inline",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -73970,15 +81162,15 @@
         {
           "kind": "TypeNominal",
           "name": "Array",
-          "printedName": "[Any]",
-          "usr": "s:Sa",
+          "printedName": "Array<Any>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ProtocolComposition",
               "printedName": "Any"
             }
-          ]
+          ],
+          "usr": "s:Sa"
         },
         {
           "kind": "TypeNominal",
@@ -73997,29 +81189,23 @@
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "Target"
+          "printedName": "τ_0_0"
         }
-      ]
+      ],
+      "declKind": "Func",
+      "usr": "s:s10debugPrint_9separator10terminator2toyypd_S2Sxzts16TextOutputStreamRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : TextOutputStream>"
     },
     {
       "kind": "TypeDecl",
       "name": "RandomNumberGenerator",
       "printedName": "RandomNumberGenerator",
-      "declKind": "Protocol",
-      "usr": "s:SG",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:SG4nexts6UInt64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomNumberGenerator>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -74027,83 +81213,73 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SG4nexts6UInt64VyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RandomNumberGenerator>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:SGsE4nextqd__ys17FixedWidthIntegerRd__SURd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : RandomNumberGenerator, T : FixedWidthInteger, T : UnsignedInteger>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SGsE4nextqd__ys17FixedWidthIntegerRd__SURd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RandomNumberGenerator, τ_1_0 : FixedWidthInteger, τ_1_0 : UnsignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next(upperBound:)",
-          "declKind": "Func",
-          "usr": "s:SGsE4next10upperBoundqd__qd___ts17FixedWidthIntegerRd__SURd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : RandomNumberGenerator, T : FixedWidthInteger, T : UnsignedInteger>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SGsE4next10upperBoundqd__qd___ts17FixedWidthIntegerRd__SURd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RandomNumberGenerator, τ_1_0 : FixedWidthInteger, τ_1_0 : UnsignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SG",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "SystemRandomNumberGenerator",
       "printedName": "SystemRandomNumberGenerator",
-      "declKind": "Struct",
-      "usr": "s:s27SystemRandomNumberGeneratorV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "RandomNumberGenerator"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s27SystemRandomNumberGeneratorVABycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -74111,20 +81287,18 @@
               "printedName": "SystemRandomNumberGenerator",
               "usr": "s:s27SystemRandomNumberGeneratorV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s27SystemRandomNumberGeneratorVABycfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s27SystemRandomNumberGeneratorV4nexts6UInt64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -74132,155 +81306,281 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s27SystemRandomNumberGeneratorV4nexts6UInt64VyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s27SystemRandomNumberGeneratorV",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "RandomNumberGenerator"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "RandomAccessCollection",
       "printedName": "RandomAccessCollection",
-      "declKind": "Protocol",
-      "usr": "s:Sk",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : BidirectionalCollection, Self.Indices : RandomAccessCollection, Self.SubSequence : RandomAccessCollection>",
-      "conformingProtocols": [
-        "BidirectionalCollection",
-        "Collection",
-        "Sequence"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Element",
+          "printedName": "Element",
+          "declKind": "AssociatedType",
+          "usr": "s:Sk7ElementQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Index",
+          "printedName": "Index",
+          "declKind": "AssociatedType",
+          "usr": "s:Sk5IndexQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "declKind": "AssociatedType",
+          "usr": "s:Sk11SubSequenceQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Indices",
+          "printedName": "Indices",
+          "declKind": "AssociatedType",
+          "usr": "s:Sk7IndicesQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:Sk7indices7IndicesQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Indices"
+              "printedName": "τ_0_0.Indices"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sk7indices7IndicesQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : RandomAccessCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Indices"
+                  "printedName": "τ_0_0.Indices"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sk7indices7IndicesQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection>",
+              "overriding": true,
+              "declAttributes": [
+                "Override"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sk7indices7IndicesQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.SubSequence"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Sky11SubSequenceQzSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Sky7ElementQz5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:Sk10startIndex0B0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sk10startIndex0B0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : RandomAccessCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sk10startIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection>",
+              "overriding": true,
+              "declAttributes": [
+                "Override"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sk10startIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:Sk8endIndex0B0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sk8endIndex0B0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : RandomAccessCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sk8endIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection>",
+              "overriding": true,
+              "declAttributes": [
+                "Override"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sk8endIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:Sk5index6before5IndexQzAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sk5index6before5IndexQzAD_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:Sk9formIndex6beforey0B0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -74290,41 +81590,49 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sk9formIndex6beforey0B0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:Sk5index5after5IndexQzAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sk5index5after5IndexQzAD_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:Sk9formIndex5aftery0B0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -74334,29 +81642,33 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sk9formIndex5aftery0B0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:Sk5index_8offsetBy5IndexQzAD_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
@@ -74364,35 +81676,35 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sk5index_8offsetBy5IndexQzAD_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:Sk5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Index?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
@@ -74403,19 +81715,19 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sk5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:Sk8distance4from2toSi5IndexQz_AEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -74426,45 +81738,42 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sk8distance4from2toSi5IndexQz_AEtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SksE5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Index?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
@@ -74475,223 +81784,232 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SksE5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE7indicesACvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
-              "printedName": "Range<Self.Index>",
-              "usr": "s:Sn",
+              "printedName": "Range<τ_0_0.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE7indicesACvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : RandomAccessCollection, Self.Index : Strideable, Self.Indices == Range<Self.Index>, Self.Index.Stride == Int>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Range",
-                  "printedName": "Range<Self.Index>",
-                  "usr": "s:Sn",
+                  "printedName": "Range<τ_0_0.Index>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Index"
+                      "printedName": "τ_0_0.Index"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE7indicesACvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection, τ_0_0.Index : Strideable, τ_0_0.Indices == Range<τ_0_0.Index>, τ_0_0.Index.Stride == Int>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE7indicesACvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE5index5afterA2B_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection, Self.Index : Strideable, Self.Indices == Range<Self.Index>, Self.Index.Stride == Int>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE5index5afterA2B_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection, τ_0_0.Index : Strideable, τ_0_0.Indices == Range<τ_0_0.Index>, τ_0_0.Index.Stride == Int>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE5index6beforeA2B_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection, Self.Index : Strideable, Self.Indices == Range<Self.Index>, Self.Index.Stride == Int>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE5index6beforeA2B_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection, τ_0_0.Index : Strideable, τ_0_0.Indices == Range<τ_0_0.Index>, τ_0_0.Index.Stride == Int>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE5index_8offsetByA2B_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection, Self.Index : Strideable, Self.Indices == Range<Self.Index>, Self.Index.Stride == Int>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index.Stride"
+              "printedName": "τ_0_0.Index.Stride"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE5index_8offsetByA2B_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection, τ_0_0.Index : Strideable, τ_0_0.Indices == Range<τ_0_0.Index>, τ_0_0.Index.Stride == Int>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE8distance4from2toSiAB_ABtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection, Self.Index : Strideable, Self.Indices == Range<Self.Index>, Self.Index.Stride == Int>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index.Stride"
+              "printedName": "τ_0_0.Index.Stride"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE8distance4from2toSiAB_ABtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RandomAccessCollection, τ_0_0.Index : Strideable, τ_0_0.Indices == Range<τ_0_0.Index>, τ_0_0.Index.Stride == Int>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:Sk",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : BidirectionalCollection, τ_0_0.Indices : RandomAccessCollection, τ_0_0.SubSequence : RandomAccessCollection>",
+      "conformingProtocols": [
+        "BidirectionalCollection",
+        "Collection",
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "RangeExpression",
       "printedName": "RangeExpression",
-      "declKind": "Protocol",
-      "usr": "s:SX",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self.Bound : Comparable>",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Bound",
+          "printedName": "Bound",
+          "declKind": "AssociatedType",
+          "usr": "s:SX5BoundQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Function",
           "name": "relative",
           "printedName": "relative(to:)",
-          "declKind": "Func",
-          "usr": "s:SX8relative2toSny5BoundQzGqd___tSlRd__5IndexQyd__ADRSlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, C where Self : RangeExpression, C : Collection, Self.Bound == C.Index>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
-              "printedName": "Range<Self.Bound>",
-              "usr": "s:Sn",
+              "printedName": "Range<τ_0_0.Bound>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Bound"
+                  "printedName": "τ_0_0.Bound"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "C"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SX8relative2toSny5BoundQzGqd___tSlRd__5IndexQyd__ADRSlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RangeExpression, τ_1_0 : Collection, τ_0_0.Bound == τ_1_0.Index>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:SX8containsySb5BoundQzF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeExpression>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -74702,21 +82020,962 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Bound"
+              "printedName": "τ_0_0.Bound"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SX8containsySb5BoundQzF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeExpression>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "~=",
+          "printedName": "~=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Bound"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SXsE2teoiySbx_5BoundQztFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeExpression>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SX",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0.Bound : Comparable>"
     },
     {
       "kind": "TypeDecl",
       "name": "Range",
       "printedName": "Range",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "lowerBound",
+          "printedName": "lowerBound",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sn10lowerBoundxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sn10lowerBoundxvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "upperBound",
+          "printedName": "upperBound",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sn10upperBoundxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sn10upperBoundxvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(uncheckedBounds:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(lower: τ_0_0, upper: τ_0_0)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sn15uncheckedBoundsSnyxGx5lower_x5uppert_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "contains",
+          "printedName": "contains(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sn8containsySbxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isEmpty",
+          "printedName": "isEmpty",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sn7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Comparable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sn7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SnsSxRzSZ6StrideRpzrlE10startIndexxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE10startIndexxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SnsSxRzSZ6StrideRpzrlE8endIndexxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE8endIndexxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE5index5afterxx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE5index6beforexx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE5index_8offsetByxx_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(from:to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE8distance4from2toSix_xtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlEySnyxGACcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "indices",
+          "printedName": "indices",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SnsSxRzSZ6StrideRpzrlE7indicesSnyxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE7indicesSnyxGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlEyxxcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SN"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlEySnyxGSNyxGcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>"
+        },
+        {
+          "kind": "Function",
+          "name": "relative",
+          "printedName": "relative(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sn8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Index, τ_1_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "clamped",
+          "printedName": "clamped(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sn7clamped2toSnyxGAC_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "description",
+          "printedName": "description",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sn11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Comparable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sn11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sn16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Comparable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sn16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "customMirror",
+          "printedName": "customMirror",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Mirror",
+              "printedName": "Mirror",
+              "usr": "s:s6MirrorV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sn12customMirrors0B0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Comparable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sn12customMirrors0B0Vvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sn2eeoiySbSnyxG_ABtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "hash",
+          "printedName": "hash(into:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Hasher",
+              "printedName": "Hasher",
+              "usr": "s:s6HasherV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SnsSHRzrlE4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable, τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "hashValue",
+          "printedName": "hashValue",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SnsSHRzrlE9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Comparable, τ_0_0 : Hashable>",
+              "implicit": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SnsSHRzrlE9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Function",
+          "name": "overlaps",
+          "printedName": "overlaps(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sn8overlapsySbSnyxGF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "overlaps",
+          "printedName": "overlaps(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SN"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sn8overlapsySbSNyxGF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlEySnyxGACcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
+          ]
+        }
+      ],
       "declKind": "Struct",
       "usr": "s:Sn",
-      "location": "",
       "moduleName": "Swift",
-      "genericSig": "<Bound where Bound : Comparable>",
+      "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "Sequence",
         "Collection",
@@ -74728,1190 +82987,119 @@
         "CustomReflectable",
         "Equatable",
         "Hashable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Var",
-          "name": "lowerBound",
-          "printedName": "lowerBound",
-          "declKind": "Var",
-          "usr": "s:Sn10lowerBoundxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sn10lowerBoundxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "declAttributes": [
-                "Transparent"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "upperBound",
-          "printedName": "upperBound",
-          "declKind": "Var",
-          "usr": "s:Sn10upperBoundxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sn10upperBoundxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "declAttributes": [
-                "Transparent"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(uncheckedBounds:)",
-          "declKind": "Constructor",
-          "usr": "s:Sn15uncheckedBoundsSnyxGx5lower_x5uppert_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Bound>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(lower: Range<Bound>.Bound, upper: Range<Bound>.Bound)",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Bound",
-                  "printedName": "Range<Bound>.Bound",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Bound",
-                  "printedName": "Range<Bound>.Bound",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "contains",
-          "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:Sn8containsySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isEmpty",
-          "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:Sn7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sn7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "IndexingIterator",
-              "printedName": "IndexingIterator<Range<Bound>>",
-              "usr": "s:s16IndexingIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Bound>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Bound"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Bound>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Bound>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE10startIndexxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SnsSxRzSZ6StrideRpzrlE10startIndexxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE8endIndexxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SnsSxRzSZ6StrideRpzrlE8endIndexxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE5index5afterxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Range<Bound>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Range<Bound>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE5index6beforexx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Range<Bound>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Range<Bound>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE5index_8offsetByxx_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Range<Bound>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Range<Bound>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE8distance4from2toSix_xtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Range<Bound>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Range<Bound>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "indices",
-          "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE7indicesSnyxGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Bound>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SnsSxRzSZ6StrideRpzrlE7indicesSnyxGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Bound>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Bound"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlEySnyxGSNyxGcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Bound>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "ClosedRange",
-              "printedName": "ClosedRange<Range<Bound>.Bound>",
-              "usr": "s:SN",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Bound",
-                  "printedName": "Range<Bound>.Bound",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "relative",
-          "printedName": "relative(to:)",
-          "declKind": "Func",
-          "usr": "s:Sn8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound, C where Bound == C.Index, C : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Bound>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "C"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Bound",
-          "printedName": "Bound",
-          "declKind": "TypeAlias",
-          "usr": "s:Sn5Bounda",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "clamped",
-          "printedName": "clamped(to:)",
-          "declKind": "Func",
-          "usr": "s:Sn7clamped2toSnyxGAC_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Bound>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Bound>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "description",
-          "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:Sn11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sn11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "debugDescription",
-          "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Sn16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sn16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Sn12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sn12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "hash",
-          "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SnsSHRzrlE4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable, Bound : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Hasher",
-              "printedName": "Hasher",
-              "usr": "s:s6HasherV"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "hashValue",
-          "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SnsSHRzrlE9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SnsSHRzrlE9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable, Bound : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "overlaps",
-          "printedName": "overlaps(_:)",
-          "declKind": "Func",
-          "usr": "s:Sn8overlapsySbSnyxGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Range<Bound>.Bound>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Bound",
-                  "printedName": "Range<Bound>.Bound",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "overlaps",
-          "printedName": "overlaps(_:)",
-          "declKind": "Func",
-          "usr": "s:Sn8overlapsySbSNyxGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "ClosedRange",
-              "printedName": "ClosedRange<Range<Bound>.Bound>",
-              "usr": "s:SN",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Bound",
-                  "printedName": "Range<Bound>.Bound",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlEySnyxGACcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Bound>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Range<Bound>.Bound>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Bound",
-                  "printedName": "Range<Bound>.Bound",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        }
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "PartialRangeUpTo",
       "printedName": "PartialRangeUpTo",
-      "declKind": "Struct",
-      "usr": "s:s16PartialRangeUpToV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Bound where Bound : Comparable>",
-      "conformingProtocols": [
-        "RangeExpression"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "upperBound",
           "printedName": "upperBound",
-          "declKind": "Var",
-          "usr": "s:s16PartialRangeUpToV10upperBoundxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Bound"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s16PartialRangeUpToV10upperBoundxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "declAttributes": [
-                "Transparent"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s16PartialRangeUpToVyAByxGxcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "PartialRangeUpTo",
-              "printedName": "PartialRangeUpTo<Bound>",
-              "usr": "s:s16PartialRangeUpToV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Bound",
-              "printedName": "PartialRangeUpTo<Bound>.Bound",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s16PartialRangeUpToV10upperBoundxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s16PartialRangeUpToV10upperBoundxvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "PartialRangeUpTo",
+              "printedName": "PartialRangeUpTo<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s16PartialRangeUpToV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s16PartialRangeUpToVyAByxGxcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "relative",
           "printedName": "relative(to:)",
-          "declKind": "Func",
-          "usr": "s:s16PartialRangeUpToV8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound, C where Bound == C.Index, C : Collection>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
-              "printedName": "Range<Bound>",
-              "usr": "s:Sn",
+              "printedName": "Range<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Bound"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "C"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16PartialRangeUpToV8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Index, τ_1_0 : Collection>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:s16PartialRangeUpToV8containsySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -75922,330 +83110,140 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Bound"
+              "printedName": "τ_0_0"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Bound",
-          "printedName": "Bound",
-          "declKind": "TypeAlias",
-          "usr": "s:s16PartialRangeUpToV5Bounda",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s16PartialRangeUpToV8containsySbxF",
           "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            }
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "declAttributes": [
+            "Transparent"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s16PartialRangeUpToV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "RangeExpression"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "PartialRangeThrough",
       "printedName": "PartialRangeThrough",
-      "declKind": "Struct",
-      "usr": "s:s19PartialRangeThroughV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Bound where Bound : Comparable>",
-      "conformingProtocols": [
-        "RangeExpression"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "upperBound",
           "printedName": "upperBound",
-          "declKind": "Var",
-          "usr": "s:s19PartialRangeThroughV10upperBoundxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Bound"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s19PartialRangeThroughV10upperBoundxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "declAttributes": [
-                "Transparent"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s19PartialRangeThroughVyAByxGxcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "PartialRangeThrough",
-              "printedName": "PartialRangeThrough<Bound>",
-              "usr": "s:s19PartialRangeThroughV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "relative",
-          "printedName": "relative(to:)",
-          "declKind": "Func",
-          "usr": "s:s19PartialRangeThroughV8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound, C where Bound == C.Index, C : Collection>",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Bound>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "C"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "contains",
-          "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:s19PartialRangeThroughV8containsySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Bound",
-          "printedName": "Bound",
-          "declKind": "TypeAlias",
-          "usr": "s:s19PartialRangeThroughV5Bounda",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "PartialRangeFrom",
-      "printedName": "PartialRangeFrom",
-      "declKind": "Struct",
-      "usr": "s:s16PartialRangeFromV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Bound where Bound : Comparable>",
-      "conformingProtocols": [
-        "RangeExpression",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Var",
-          "name": "lowerBound",
-          "printedName": "lowerBound",
-          "declKind": "Var",
-          "usr": "s:s16PartialRangeFromV10lowerBoundxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s16PartialRangeFromV10lowerBoundxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "declAttributes": [
-                "Transparent"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s16PartialRangeFromVyAByxGxcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "PartialRangeFrom",
-              "printedName": "PartialRangeFrom<Bound>",
-              "usr": "s:s16PartialRangeFromV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Bound",
-              "printedName": "PartialRangeFrom<Bound>.Bound",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s19PartialRangeThroughV10upperBoundxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s19PartialRangeThroughV10upperBoundxvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "PartialRangeThrough",
+              "printedName": "PartialRangeThrough<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s19PartialRangeThroughV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s19PartialRangeThroughVyAByxGxcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "relative",
           "printedName": "relative(to:)",
-          "declKind": "Func",
-          "usr": "s:s16PartialRangeFromV8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound, C where Bound == C.Index, C : Collection>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
-              "printedName": "Range<Bound>",
-              "usr": "s:Sn",
+              "printedName": "Range<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Bound"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "C"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s19PartialRangeThroughV8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Index, τ_1_0 : Collection>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:s16PartialRangeFromV8containsySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -76256,303 +83254,355 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Bound"
+              "printedName": "τ_0_0"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Bound",
-          "printedName": "Bound",
-          "declKind": "TypeAlias",
-          "usr": "s:s16PartialRangeFromV5Bounda",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s19PartialRangeThroughV8containsySbxF",
           "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "declAttributes": [
+            "Transparent"
+          ]
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s19PartialRangeThroughV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "RangeExpression"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "PartialRangeFrom",
+      "printedName": "PartialRangeFrom",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "lowerBound",
+          "printedName": "lowerBound",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Bound"
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s16PartialRangeFromV10lowerBoundxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s16PartialRangeFromV10lowerBoundxvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
         },
         {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
           "children": [
             {
               "kind": "TypeNominal",
+              "name": "PartialRangeFrom",
+              "printedName": "PartialRangeFrom<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s16PartialRangeFromV"
+            },
+            {
+              "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Bound"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s16PartialRangeFromVyAByxGxcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "relative",
+          "printedName": "relative(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16PartialRangeFromV8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Index, τ_1_0 : Collection>",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "contains",
+          "printedName": "contains(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16PartialRangeFromV8containsySbxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "conformingProtocols": [
-            "IteratorProtocol"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "Function",
-              "name": "next",
-              "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE8IteratorV4nextxSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "PartialRangeFrom<Bound>.Bound?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Bound",
-                      "printedName": "PartialRangeFrom<Bound>.Bound",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_0"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+              "kind": "Var",
+              "name": "_current",
+              "printedName": "_current",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Bound"
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE8IteratorV8_currentxvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE8IteratorV8_currentxvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Function",
+              "name": "next",
+              "printedName": "next()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE8IteratorV4nextxSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE12makeIteratorABsSxRzSZADRQrlE0F0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Iterator",
-              "printedName": "PartialRangeFrom<Bound>.Iterator",
+              "printedName": "PartialRangeFrom<τ_0_0>.Iterator",
               "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE8IteratorV"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE11SubSequencea",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE12makeIteratorABsSxRzSZADRQrlE0F0Vyx_GyF",
           "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnySequence",
-              "printedName": "AnySequence<Bound>",
-              "usr": "s:s11AnySequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s16PartialRangeFromV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "RangeExpression",
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnboundedRange_",
       "printedName": "UnboundedRange_",
+      "children": [
+        {
+          "kind": "Function",
+          "name": "...",
+          "printedName": "...(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnboundedRange_",
+              "printedName": "UnboundedRange_",
+              "usr": "s:s15UnboundedRange_O"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15UnboundedRange_O3zzzoPyyABFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Postfix"
+          ]
+        }
+      ],
       "declKind": "Enum",
       "usr": "s:s15UnboundedRange_O",
-      "location": "",
       "moduleName": "Swift",
       "declAttributes": [
         "Frozen"
       ]
     },
     {
-      "kind": "TypeAlias",
-      "name": "UnboundedRange",
-      "printedName": "UnboundedRange",
-      "declKind": "TypeAlias",
-      "usr": "s:s14UnboundedRangea",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeFunc",
-          "name": "Function",
-          "printedName": "(UnboundedRange_) -> ()",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Paren",
-              "printedName": "(UnboundedRange_)",
-              "usr": "s:s15UnboundedRange_O",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnboundedRange_",
-                  "printedName": "UnboundedRange_",
-                  "usr": "s:s15UnboundedRange_O"
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CountableRange",
-      "printedName": "CountableRange",
-      "declKind": "TypeAlias",
-      "usr": "s:s14CountableRangea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Range",
-          "printedName": "Range<Bound>",
-          "usr": "s:Sn",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CountablePartialRangeFrom",
-      "printedName": "CountablePartialRangeFrom",
-      "declKind": "TypeAlias",
-      "usr": "s:s25CountablePartialRangeFroma",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "PartialRangeFrom",
-          "printedName": "PartialRangeFrom<Bound>",
-          "usr": "s:s16PartialRangeFromV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Bound"
-            }
-          ]
-        }
-      ]
-    },
-    {
       "kind": "TypeDecl",
       "name": "RangeReplaceableCollection",
       "printedName": "RangeReplaceableCollection",
-      "declKind": "Protocol",
-      "usr": "s:Sm",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Collection, Self.SubSequence : RangeReplaceableCollection>",
-      "conformingProtocols": [
-        "Collection",
-        "Sequence"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "declKind": "AssociatedType",
+          "usr": "s:Sm11SubSequenceQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:Smxycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Smxycfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "replaceSubrange",
           "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:Sm15replaceSubrange_4withySny5IndexQzG_qd__tSlRd__7ElementQyd__AFRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, C where Self : RangeReplaceableCollection, C : Collection, Self.Element == C.Element>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76562,33 +83612,33 @@
             {
               "kind": "TypeNominal",
               "name": "Range",
-              "printedName": "Range<Self.Index>",
-              "usr": "s:Sn",
+              "printedName": "Range<τ_0_0.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "C"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm15replaceSubrange_4withySny5IndexQzG_qd__ntSlRd__7ElementQyd__AFRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RangeReplaceableCollection, τ_1_0 : Collection, τ_0_0.Element == τ_1_0.Element>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "reserveCapacity",
           "printedName": "reserveCapacity(_:)",
-          "declKind": "Func",
-          "usr": "s:Sm15reserveCapacityyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76601,27 +83651,28 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm15reserveCapacityyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(repeating:count:)",
-          "declKind": "Constructor",
-          "usr": "s:Sm9repeating5countx7ElementQz_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             },
             {
               "kind": "TypeNominal",
@@ -76629,40 +83680,39 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sm9repeating5countx7ElementQz_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:Smyxqd__cSTRd__7ElementQyd__AARtzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, S where Self : RangeReplaceableCollection, S : Sequence, Self.Element == S.Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "S"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Smyxqd__cSTRd__7ElementQyd__AARtzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RangeReplaceableCollection, τ_1_0 : Sequence, τ_0_0.Element == τ_1_0.Element>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(_:)",
-          "declKind": "Func",
-          "usr": "s:Sm6appendyy7ElementQznF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76672,20 +83722,20 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm6appendyy7ElementQznF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:Sm6append10contentsOfyqd__n_tSTRd__7ElementQyd__ACRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, S where Self : RangeReplaceableCollection, S : Sequence, Self.Element == S.Element>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76695,20 +83745,20 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "S"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm6append10contentsOfyqd__n_tSTRd__7ElementQyd__ACRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RangeReplaceableCollection, τ_1_0 : Sequence, τ_0_0.Element == τ_1_0.Element>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(_:at:)",
-          "declKind": "Func",
-          "usr": "s:Sm6insert_2aty7ElementQzn_5IndexQztF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76718,25 +83768,25 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm6insert_2aty7ElementQzn_5IndexQztF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(contentsOf:at:)",
-          "declKind": "Func",
-          "usr": "s:Sm6insert10contentsOf2atyqd__n_5IndexQztSlRd__7ElementQyd__AFRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, S where Self : RangeReplaceableCollection, S : Collection, Self.Element == S.Element>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76746,51 +83796,51 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "S"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm6insert10contentsOf2atyqd__n_5IndexQztSlRd__7ElementQyd__AFRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RangeReplaceableCollection, τ_1_0 : Collection, τ_0_0.Element == τ_1_0.Element>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "remove",
           "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:Sm6remove2at7ElementQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm6remove2at7ElementQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "declAttributes": [
+            "DiscardableResult"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeSubrange",
           "printedName": "removeSubrange(_:)",
-          "declKind": "Func",
-          "usr": "s:Sm14removeSubrangeyySny5IndexQzGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76800,49 +83850,49 @@
             {
               "kind": "TypeNominal",
               "name": "Range",
-              "printedName": "Range<Self.Index>",
-              "usr": "s:Sn",
+              "printedName": "Range<τ_0_0.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm14removeSubrangeyySny5IndexQzGF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeFirst",
           "printedName": "removeFirst()",
-          "declKind": "Func",
-          "usr": "s:Sm11removeFirst7ElementQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm11removeFirst7ElementQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "declAttributes": [
+            "DiscardableResult"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeFirst",
           "printedName": "removeFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:Sm11removeFirstyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76855,18 +83905,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm11removeFirstyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeAll",
           "printedName": "removeAll(keepingCapacity:)",
-          "declKind": "Func",
-          "usr": "s:Sm9removeAll15keepingCapacityySb_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76879,22 +83929,18 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm9removeAll15keepingCapacityySb_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeAll",
           "printedName": "removeAll(where:)",
-          "declKind": "Func",
-          "usr": "s:Sm9removeAll5whereySb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -76904,10 +83950,7 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -76917,42 +83960,100 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm9removeAll5whereySb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true,
+          "mutating": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Smy7ElementQz5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.SubSequence"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Smy11SubSequenceQzSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(repeating:count:)",
-          "declKind": "Constructor",
-          "usr": "s:SmsE9repeating5countx7ElementQz_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             },
             {
               "kind": "TypeNominal",
@@ -76960,46 +84061,43 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SmsE9repeating5countx7ElementQz_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SmsEyxqd__cSTRd__7ElementQyd__AARtzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, S where Self : RangeReplaceableCollection, S : Sequence, Self.Element == S.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "S"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SmsEyxqd__cSTRd__7ElementQyd__AARtzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RangeReplaceableCollection, τ_1_0 : Sequence, τ_0_0.Element == τ_1_0.Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(_:)",
-          "declKind": "Func",
-          "usr": "s:SmsE6appendyy7ElementQzF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77009,23 +84107,22 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE6appendyy7ElementQznF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:SmsE6append10contentsOfyqd___tSTRd__7ElementQyd__ACRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, S where Self : RangeReplaceableCollection, S : Sequence, Self.Element == S.Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77035,23 +84132,22 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "S"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE6append10contentsOfyqd__n_tSTRd__7ElementQyd__ACRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RangeReplaceableCollection, τ_1_0 : Sequence, τ_0_0.Element == τ_1_0.Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(_:at:)",
-          "declKind": "Func",
-          "usr": "s:SmsE6insert_2aty7ElementQz_5IndexQztF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77061,28 +84157,27 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE6insert_2aty7ElementQzn_5IndexQztF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(contentsOf:at:)",
-          "declKind": "Func",
-          "usr": "s:SmsE6insert10contentsOf2atyqd___5IndexQztSlRd__7ElementQyd__AFRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, C where Self : RangeReplaceableCollection, C : Collection, Self.Element == C.Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77092,55 +84187,53 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "C"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE6insert10contentsOf2atyqd__n_5IndexQztSlRd__7ElementQyd__AFRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RangeReplaceableCollection, τ_1_0 : Collection, τ_0_0.Element == τ_1_0.Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "remove",
           "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:SmsE6remove2at7ElementQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Index"
+              "printedName": "τ_0_0.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE6remove2at7ElementQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeSubrange",
           "printedName": "removeSubrange(_:)",
-          "declKind": "Func",
-          "usr": "s:SmsE14removeSubrangeyySny5IndexQzGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77150,31 +84243,30 @@
             {
               "kind": "TypeNominal",
               "name": "Range",
-              "printedName": "Range<Self.Index>",
-              "usr": "s:Sn",
+              "printedName": "Range<τ_0_0.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Index"
+                  "printedName": "τ_0_0.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE14removeSubrangeyySny5IndexQzGF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeFirst",
           "printedName": "removeFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:SmsE11removeFirstyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77187,43 +84279,41 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE11removeFirstyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeFirst",
           "printedName": "removeFirst()",
-          "declKind": "Func",
-          "usr": "s:SmsE11removeFirst7ElementQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE11removeFirst7ElementQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeAll",
           "printedName": "removeAll(keepingCapacity:)",
-          "declKind": "Func",
-          "usr": "s:SmsE9removeAll15keepingCapacityySb_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77237,21 +84327,20 @@
               "hasDefaultArg": true,
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE9removeAll15keepingCapacityySb_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "reserveCapacity",
           "printedName": "reserveCapacity(_:)",
-          "declKind": "Func",
-          "usr": "s:SmsE15reserveCapacityyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77264,43 +84353,41 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE15reserveCapacityyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeFirst",
           "printedName": "removeFirst()",
-          "declKind": "Func",
-          "usr": "s:Sms11SubSequenceQzRszrlE11removeFirst7ElementQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sms11SubSequenceQzRszrlE11removeFirst7ElementQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection, τ_0_0 == τ_0_0.SubSequence>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeFirst",
           "printedName": "removeFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:Sms11SubSequenceQzRszrlE11removeFirstyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77313,21 +84400,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sms11SubSequenceQzRszrlE11removeFirstyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection, τ_0_0 == τ_0_0.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "replaceSubrange",
           "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:SmsE15replaceSubrange_4withyqd_0__qd__tSlRd__SXRd_0_7ElementQyd__ACRtz5BoundQyd_0_5IndexRtzr0_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, C, R where Self : RangeReplaceableCollection, C : Collection, R : RangeExpression, Self.Element == C.Element, Self.Index == R.Bound>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77337,28 +84423,27 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "R"
+              "printedName": "τ_1_1"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "C"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE15replaceSubrange_4withyqd_0__qd__ntSlRd__SXRd_0_7ElementQyd__ACRtz5BoundQyd_0_5IndexRtzr0_lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0, τ_1_1 where τ_0_0 : RangeReplaceableCollection, τ_1_0 : Collection, τ_1_1 : RangeExpression, τ_0_0.Element == τ_1_0.Element, τ_0_0.Index == τ_1_1.Bound>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeSubrange",
           "printedName": "removeSubrange(_:)",
-          "declKind": "Func",
-          "usr": "s:SmsE14removeSubrangeyyqd__SXRd__5BoundQyd__5IndexRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, R where Self : RangeReplaceableCollection, R : RangeExpression, Self.Index == R.Bound>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77368,74 +84453,71 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "R"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE14removeSubrangeyyqd__SXRd__5BoundQyd__5IndexRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RangeReplaceableCollection, τ_1_0 : RangeExpression, τ_0_0.Index == τ_1_0.Bound>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "popLast",
           "printedName": "popLast()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0.Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ],
+              "usr": "s:Sq"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SmsSKRzrlE7popLast7ElementSTQzSgyF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self : RangeReplaceableCollection>",
-          "mutating": true,
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0 : RangeReplaceableCollection>",
           "declAttributes": [
             "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Element"
-                }
-              ]
-            }
-          ]
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeLast",
           "printedName": "removeLast()",
-          "declKind": "Func",
-          "usr": "s:SmsSKRzrlE10removeLast7ElementSTQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsSKRzrlE10removeLast7ElementSTQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeLast",
           "printedName": "removeLast(_:)",
-          "declKind": "Func",
-          "usr": "s:SmsSKRzrlE10removeLastyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77448,72 +84530,69 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsSKRzrlE10removeLastyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "popLast",
           "printedName": "popLast()",
-          "declKind": "Func",
-          "usr": "s:SmsSKRz11SubSequenceSTQzRszrlE7popLast7ElementSTQzSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self : RangeReplaceableCollection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsSKRz11SubSequenceSTQzRszrlE7popLast7ElementSTQzSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0 : RangeReplaceableCollection, τ_0_0 == τ_0_0.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeLast",
           "printedName": "removeLast()",
-          "declKind": "Func",
-          "usr": "s:SmsSKRz11SubSequenceSTQzRszrlE10removeLast7ElementSTQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self : RangeReplaceableCollection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsSKRz11SubSequenceSTQzRszrlE10removeLast7ElementSTQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0 : RangeReplaceableCollection, τ_0_0 == τ_0_0.SubSequence>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeLast",
           "printedName": "removeLast(_:)",
-          "declKind": "Func",
-          "usr": "s:SmsSKRz11SubSequenceSTQzRszrlE10removeLastyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self : RangeReplaceableCollection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77526,74 +84605,226 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsSKRz11SubSequenceSTQzRszrlE10removeLastyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0 : RangeReplaceableCollection, τ_0_0 == τ_0_0.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE1poiyxx_qd__tSTRd__7ElementQyd__ABRtzlFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RangeReplaceableCollection, τ_1_0 : Sequence, τ_0_0.Element == τ_1_0.Element>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE1poiyxqd___xtSTRd__7ElementQyd__ABRtzlFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RangeReplaceableCollection, τ_1_0 : Sequence, τ_0_0.Element == τ_1_0.Element>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE2peoiyyxz_qd__tSTRd__7ElementQyd__ABRtzlFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RangeReplaceableCollection, τ_1_0 : Sequence, τ_0_0.Element == τ_1_0.Element>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE1poiyxx_qd__tSmRd__7ElementQyd__ABRtzlFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RangeReplaceableCollection, τ_1_0 : RangeReplaceableCollection, τ_0_0.Element == τ_1_0.Element>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "filter",
+          "printedName": "filter(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Element) throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE6filteryxSb7ElementQzKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Rethrows",
+            "Available",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
           "name": "removeAll",
           "printedName": "removeAll(where:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Element) throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SmsSMRzrlE9removeAll5whereySb7ElementSTQzKXE_tKF",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : MutableCollection, Self : RangeReplaceableCollection>",
-          "throwing": true,
-          "mutating": true,
+          "genericSig": "<τ_0_0 where τ_0_0 : MutableCollection, τ_0_0 : RangeReplaceableCollection>",
           "declAttributes": [
             "Rethrows",
             "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeAll",
           "printedName": "removeAll(where:)",
-          "declKind": "Func",
-          "usr": "s:SmsE9removeAll5whereySb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77603,10 +84834,7 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -77616,49 +84844,45 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE9removeAll5whereySb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:Sm",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : Collection, τ_0_0.SubSequence : RangeReplaceableCollection>",
+      "conformingProtocols": [
+        "Collection",
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Repeated",
       "printedName": "Repeated",
-      "declKind": "Struct",
-      "usr": "s:s8RepeatedV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "RandomAccessCollection",
-        "BidirectionalCollection",
-        "Collection",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s8RepeatedV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -77670,14 +84894,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s8RepeatedV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -77685,68 +84901,79 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s8RepeatedV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s8RepeatedV5countSivp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Var",
           "name": "repeatedValue",
           "printedName": "repeatedValue",
-          "declKind": "Var",
-          "usr": "s:s8RepeatedV13repeatedValuexvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Element"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s8RepeatedV13repeatedValuexvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s8RepeatedV13repeatedValuexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s8RepeatedV13repeatedValuexvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(count:repeatedValue:)",
-          "declKind": "Constructor",
-          "usr": "s:s8RepeatedV5count13repeatedValueAByxGSi_xtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Repeated",
-              "printedName": "Repeated<Element>",
-              "usr": "s:s8RepeatedV",
+              "printedName": "Repeated<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s8RepeatedV"
             },
             {
               "kind": "TypeNominal",
@@ -77757,70 +84984,31 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Element"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s8RepeatedV5count13repeatedValueAByxGSi_xtcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "implicit": true,
+          "isInternal": true
         },
         {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s8RepeatedV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Int>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s8RepeatedV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Int",
               "printedName": "Int",
               "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s8RepeatedV10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
+            },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Repeated<Element>.Index",
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -77828,51 +85016,35 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
+              ],
               "declKind": "Accessor",
               "usr": "s:s8RepeatedV10startIndexSivg",
-              "location": "",
               "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Repeated<Element>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s8RepeatedV10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s8RepeatedV8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Repeated<Element>.Index",
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -77880,150 +85052,82 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
+              ],
               "declKind": "Accessor",
               "usr": "s:s8RepeatedV8endIndexSivg",
-              "location": "",
               "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Repeated<Element>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s8RepeatedV8endIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s8RepeatedV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s8RepeatedV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
+              "printedName": "τ_0_0"
+            },
             {
               "kind": "TypeNominal",
-              "name": "IndexingIterator",
-              "printedName": "IndexingIterator<Repeated<Element>>",
-              "usr": "s:s16IndexingIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Repeated",
-                  "printedName": "Repeated<Element>",
-                  "usr": "s:s8RepeatedV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s8RepeatedV11SubSequencea",
-          "location": "",
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s8RepeatedVyxSicip",
           "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<Repeated<Element>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Repeated",
-                  "printedName": "Repeated<Element>",
-                  "usr": "s:s8RepeatedV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s8RepeatedV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "RandomAccessCollection",
+        "BidirectionalCollection",
+        "Collection",
+        "Sequence"
       ]
     },
     {
       "kind": "Function",
       "name": "repeatElement",
       "printedName": "repeatElement(_:count:)",
-      "declKind": "Func",
-      "usr": "s:s13repeatElement_5counts8RepeatedVyxGx_SitlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Repeated",
-          "printedName": "Repeated<T>",
-          "usr": "s:s8RepeatedV",
+          "printedName": "Repeated<τ_0_0>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "usr": "s:s8RepeatedV"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
@@ -78031,301 +85135,349 @@
           "printedName": "Int",
           "usr": "s:Si"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s13repeatElement_5counts8RepeatedVyxGx_SitlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "ReversedCollection",
       "printedName": "ReversedCollection",
-      "declKind": "Struct",
-      "usr": "s:s18ReversedCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : BidirectionalCollection>",
-      "conformingProtocols": [
-        "LazySequenceProtocol",
-        "LazyCollectionProtocol",
-        "Sequence",
-        "BidirectionalCollection",
-        "Collection",
-        "RandomAccessCollection"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "Elements",
-          "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s18ReversedCollectionVss20LazySequenceProtocolRzrlE8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection, Base : LazySequenceProtocol>",
+          "kind": "Var",
+          "name": "_base",
+          "printedName": "_base",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "ReversedCollection",
-              "printedName": "ReversedCollection<Base>",
-              "usr": "s:s18ReversedCollectionV",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Base"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s18ReversedCollectionV5_basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s18ReversedCollectionV5_basexvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s18ReversedCollectionV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "conformingProtocols": [
-            "IteratorProtocol",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s18ReversedCollectionV8IteratorV7Elementa",
-              "location": "",
+              "kind": "Var",
+              "name": "_base",
+              "printedName": "_base",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s18ReversedCollectionV8IteratorV5_basexvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s18ReversedCollectionV8IteratorV5_basexvp",
               "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection>",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "isLet": true,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_position",
+              "printedName": "_position",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Base.Element"
+                  "printedName": "τ_0_0.Index"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Index"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s18ReversedCollectionV8IteratorV9_position5IndexQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s18ReversedCollectionV8IteratorV9_position5IndexQzvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 1,
+              "hasStorage": true
             },
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s18ReversedCollectionV8IteratorV4next7ElementQzSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection>",
-              "mutating": true,
-              "declAttributes": [
-                "Inline",
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "ReversedCollection<Base>.Iterator.Element?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "ReversedCollection<Base>.Iterator.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "DependentMember",
-                          "printedName": "τ_0_0.Element"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s18ReversedCollectionV8IteratorVACa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "ReversedCollection<Base>.Iterator",
-                  "usr": "s:s18ReversedCollectionV8IteratorV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s18ReversedCollectionV8IteratorV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnySequence",
-                  "printedName": "AnySequence<Base.Element>",
-                  "usr": "s:s11AnySequenceV",
+                  "printedName": "Optional<τ_0_0.Element>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Base.Element"
+                      "printedName": "τ_0_0.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s18ReversedCollectionV8IteratorV4next7ElementQzSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
+              ],
+              "mutating": true
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s18ReversedCollectionV7Elementa",
-          "location": "",
+          ],
+          "declKind": "Struct",
+          "usr": "s:s18ReversedCollectionV8IteratorV",
           "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element"
-            }
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "Sequence"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s18ReversedCollectionV12makeIteratorAB0D0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Iterator",
-              "printedName": "ReversedCollection<Base>.Iterator",
+              "printedName": "ReversedCollection<τ_0_0>.Iterator",
               "usr": "s:s18ReversedCollectionV8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s18ReversedCollectionV12makeIteratorAB0D0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "Struct",
-          "usr": "s:s18ReversedCollectionV5IndexV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "conformingProtocols": [
-            "Comparable",
-            "Equatable",
-            "Hashable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "base",
               "printedName": "base",
-              "declKind": "Var",
-              "usr": "s:s18ReversedCollectionV5IndexV4baseACQzvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Base.Index"
+                  "printedName": "τ_0_0.Index"
                 },
                 {
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s18ReversedCollectionV5IndexV4baseACQzvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Base where Base : BidirectionalCollection>",
-                  "declAttributes": [
-                    "Transparent"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Base.Index"
+                      "printedName": "τ_0_0.Index"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s18ReversedCollectionV5IndexV4baseACQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+                  "implicit": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s18ReversedCollectionV5IndexV4baseACQzvp",
+              "moduleName": "Swift",
+              "fixedbinaryorder": 0,
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s18ReversedCollectionV5IndexVyADyx_GACQzcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "ReversedCollection<Base>.Index",
+                  "printedName": "ReversedCollection<τ_0_0>.Index",
                   "usr": "s:s18ReversedCollectionV5IndexV"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Base.Index"
+                  "printedName": "τ_0_0.Index"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s18ReversedCollectionV5IndexVyADyx_GACQzcfc",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ReversedCollection<τ_0_0>.Index",
+                  "usr": "s:s18ReversedCollectionV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ReversedCollection<τ_0_0>.Index",
+                  "usr": "s:s18ReversedCollectionV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s18ReversedCollectionV5IndexV2eeoiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ReversedCollection<τ_0_0>.Index",
+                  "usr": "s:s18ReversedCollectionV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ReversedCollection<τ_0_0>.Index",
+                  "usr": "s:s18ReversedCollectionV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s18ReversedCollectionV5IndexV1loiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s18ReversedCollectionV5IndexVsSHACRpzrlE4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection, Base.Index : Hashable>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -78338,16 +85490,19 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s18ReversedCollectionV5IndexVsSHACRpzrlE4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0.Index : Hashable>",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s18ReversedCollectionV5IndexVsSHACRpzrlE9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -78359,11 +85514,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s18ReversedCollectionV5IndexVsSHACRpzrlE9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Base where Base : BidirectionalCollection, Base.Index : Hashable>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -78371,165 +85521,172 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s18ReversedCollectionV5IndexVsSHACRpzrlE9hashValueSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0.Index : Hashable>",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s18ReversedCollectionV5IndexVsSHACRpzrlE9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s18ReversedCollectionV5IndexV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "Comparable",
+            "Equatable",
+            "Hashable"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s18ReversedCollectionV10startIndexAB0D0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ReversedCollection<Base>.Index",
+              "printedName": "ReversedCollection<τ_0_0>.Index",
               "usr": "s:s18ReversedCollectionV5IndexV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s18ReversedCollectionV10startIndexAB0D0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "ReversedCollection<Base>.Index",
+                  "printedName": "ReversedCollection<τ_0_0>.Index",
                   "usr": "s:s18ReversedCollectionV5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s18ReversedCollectionV10startIndexAB0D0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s18ReversedCollectionV10startIndexAB0D0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s18ReversedCollectionV8endIndexAB0D0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ReversedCollection<Base>.Index",
+              "printedName": "ReversedCollection<τ_0_0>.Index",
               "usr": "s:s18ReversedCollectionV5IndexV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s18ReversedCollectionV8endIndexAB0D0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "ReversedCollection<Base>.Index",
+                  "printedName": "ReversedCollection<τ_0_0>.Index",
                   "usr": "s:s18ReversedCollectionV5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s18ReversedCollectionV8endIndexAB0D0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s18ReversedCollectionV8endIndexAB0D0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s18ReversedCollectionV5index5afterAB5IndexVyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ReversedCollection<Base>.Index",
+              "printedName": "ReversedCollection<τ_0_0>.Index",
               "usr": "s:s18ReversedCollectionV5IndexV"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ReversedCollection<Base>.Index",
+              "printedName": "ReversedCollection<τ_0_0>.Index",
               "usr": "s:s18ReversedCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s18ReversedCollectionV5index5afterAB5IndexVyx_GAG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s18ReversedCollectionV5index6beforeAB5IndexVyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ReversedCollection<Base>.Index",
+              "printedName": "ReversedCollection<τ_0_0>.Index",
               "usr": "s:s18ReversedCollectionV5IndexV"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ReversedCollection<Base>.Index",
+              "printedName": "ReversedCollection<τ_0_0>.Index",
               "usr": "s:s18ReversedCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s18ReversedCollectionV5index6beforeAB5IndexVyx_GAG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s18ReversedCollectionV5index_8offsetByAB5IndexVyx_GAG_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ReversedCollection<Base>.Index",
+              "printedName": "ReversedCollection<τ_0_0>.Index",
               "usr": "s:s18ReversedCollectionV5IndexV"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ReversedCollection<Base>.Index",
+              "printedName": "ReversedCollection<τ_0_0>.Index",
               "usr": "s:s18ReversedCollectionV5IndexV"
             },
             {
@@ -78538,39 +85695,38 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s18ReversedCollectionV5index_8offsetByAB5IndexVyx_GAG_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s18ReversedCollectionV5index_8offsetBy07limitedE0AB5IndexVyx_GSgAH_SiAHtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "ReversedCollection<Base>.Index?",
-              "usr": "s:Sq",
+              "printedName": "Optional<ReversedCollection<τ_0_0>.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Index",
-                  "printedName": "ReversedCollection<Base>.Index",
+                  "printedName": "ReversedCollection<τ_0_0>.Index",
                   "usr": "s:s18ReversedCollectionV5IndexV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ReversedCollection<Base>.Index",
+              "printedName": "ReversedCollection<τ_0_0>.Index",
               "usr": "s:s18ReversedCollectionV5IndexV"
             },
             {
@@ -78582,23 +85738,22 @@
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ReversedCollection<Base>.Index",
+              "printedName": "ReversedCollection<τ_0_0>.Index",
               "usr": "s:s18ReversedCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s18ReversedCollectionV5index_8offsetBy07limitedE0AB5IndexVyx_GSgAH_SiAHtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s18ReversedCollectionV8distance4from2toSiAB5IndexVyx_G_AHtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -78609,157 +85764,199 @@
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ReversedCollection<Base>.Index",
+              "printedName": "ReversedCollection<τ_0_0>.Index",
               "usr": "s:s18ReversedCollectionV5IndexV"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "ReversedCollection<Base>.Index",
+              "printedName": "ReversedCollection<τ_0_0>.Index",
               "usr": "s:s18ReversedCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s18ReversedCollectionV8distance4from2toSiAB5IndexVyx_G_AHtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s18ReversedCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<ReversedCollection<Base>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "ReversedCollection",
-                  "printedName": "ReversedCollection<Base>",
-                  "usr": "s:s18ReversedCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Base"
-                    }
-                  ]
-                }
-              ]
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "ReversedCollection<τ_0_0>.Index",
+              "usr": "s:s18ReversedCollectionV5IndexV"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s18ReversedCollectionVy7ElementQzAB5IndexVyx_Gcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s18ReversedCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "kind": "Function",
+          "name": "reversed",
+          "printedName": "reversed()",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "DefaultIndices",
-              "printedName": "DefaultIndices<ReversedCollection<Base>>",
-              "usr": "s:SI",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "ReversedCollection",
-                  "printedName": "ReversedCollection<Base>",
-                  "usr": "s:s18ReversedCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Base"
-                    }
-                  ]
-                }
-              ]
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s18ReversedCollectionV8reversedxyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Available",
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s18ReversedCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "LazySequenceProtocol",
+        "LazyCollectionProtocol",
+        "Sequence",
+        "BidirectionalCollection",
+        "Collection",
+        "RandomAccessCollection"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "IteratorProtocol",
       "printedName": "IteratorProtocol",
-      "declKind": "Protocol",
-      "usr": "s:St",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Element",
+          "printedName": "Element",
+          "declKind": "AssociatedType",
+          "usr": "s:St7ElementQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:St4next7ElementQzSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : IteratorProtocol>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:St4next7ElementQzSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : IteratorProtocol>",
+          "protocolReq": true,
+          "mutating": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:St",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "Sequence",
       "printedName": "Sequence",
-      "declKind": "Protocol",
-      "usr": "s:ST",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self.Element == Self.Iterator.Element, Self.Iterator : IteratorProtocol, Self.SubSequence : Sequence, Self.SubSequence == Self.SubSequence.SubSequence, Self.Iterator.Element == Self.SubSequence.Element, Self.SubSequence.Element == Self.SubSequence.Iterator.Element>",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Element",
+          "printedName": "Element",
+          "declKind": "AssociatedType",
+          "usr": "s:ST7ElementQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Iterator",
+          "printedName": "Iterator",
+          "declKind": "AssociatedType",
+          "usr": "s:ST8IteratorQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "AnySequence",
+              "printedName": "AnySequence<τ_0_0.Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ],
+              "usr": "s:s11AnySequenceV"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:ST11SubSequenceQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:ST12makeIterator0B0QzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Iterator"
+              "printedName": "τ_0_0.Iterator"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST12makeIterator0B0QzyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:ST19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -78771,11 +85968,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:ST19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -78783,100 +85975,89 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:ST19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:ST19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:ST3mapySayqd__Gqd__7ElementQzKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[T]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> T",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> τ_1_0",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST3mapySayqd__Gqd__7ElementQzKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Sequence>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:ST6filterySay7ElementQzGSbACKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Self.Element]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -78886,33 +86067,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST6filterySay7ElementQzGSbACKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "forEach",
           "printedName": "forEach(_:)",
-          "declKind": "Func",
-          "usr": "s:ST7forEachyyy7ElementQzKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -78922,53 +86099,43 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> ()",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
+                  "kind": "TypeNominal",
                   "name": "Void",
-                  "printedName": "Void",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Void",
-                      "printedName": "()"
-                    }
-                  ]
+                  "printedName": "()"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST7forEachyyy7ElementQzKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:ST9dropFirsty11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
@@ -78976,22 +86143,22 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST9dropFirsty11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:ST8dropLasty11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
@@ -78999,34 +86166,27 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST8dropLasty11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:ST4drop5while11SubSequenceQzSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -79036,34 +86196,34 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST4drop5while11SubSequenceQzSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(_:)",
-          "declKind": "Func",
-          "usr": "s:ST6prefixy11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
@@ -79071,34 +86231,27 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST6prefixy11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:ST6prefix5while11SubSequenceQzSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -79108,34 +86261,34 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST6prefix5while11SubSequenceQzSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:ST6suffixy11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
@@ -79143,34 +86296,30 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST6suffixy11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(maxSplits:omittingEmptySubsequences:whereSeparator:)",
-          "declKind": "Func",
-          "usr": "s:ST5split9maxSplits25omittingEmptySubsequences14whereSeparatorSay11SubSequenceQzGSi_S2b7ElementQzKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Self.SubSequence]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0.SubSequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.SubSequence"
+                  "printedName": "τ_0_0.SubSequence"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -79187,10 +86336,7 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -79200,306 +86346,283 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST5split9maxSplits25omittingEmptySubsequences14whereSeparatorSay11SubSequenceQzGSi_S2b7ElementQzKXEtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "shuffled",
           "printedName": "shuffled(using:)",
-          "declKind": "Func",
-          "usr": "s:STsE8shuffled5usingSay7ElementQzGqd__z_tSGRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Sequence, T : RandomNumberGenerator>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Self.Element]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE8shuffled5usingSay7ElementQzGqd__z_tSGRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Sequence, τ_1_0 : RandomNumberGenerator>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "shuffled",
           "printedName": "shuffled()",
-          "declKind": "Func",
-          "usr": "s:STsE8shuffledSay7ElementQzGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Self.Element]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE8shuffledSay7ElementQzGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "joined",
           "printedName": "joined()",
-          "declKind": "Func",
-          "usr": "s:STsST7ElementRpzrlE6joineds15FlattenSequenceVyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.Element : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "FlattenSequence",
-              "printedName": "FlattenSequence<Self>",
-              "usr": "s:s15FlattenSequenceV",
+              "printedName": "FlattenSequence<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s15FlattenSequenceV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsST7ElementRpzrlE6joineds15FlattenSequenceVyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "joined",
           "printedName": "joined(separator:)",
-          "declKind": "Func",
-          "usr": "s:STsST7ElementRpzrlE6joined9separators14JoinedSequenceVyxGqd___tSTRd__AA_AAQZAARtd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Separator where Self : Sequence, Separator : Sequence, Self.Element : Sequence, Separator.Element == Self.Element.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "JoinedSequence",
-              "printedName": "JoinedSequence<Self>",
-              "usr": "s:s14JoinedSequenceV",
+              "printedName": "JoinedSequence<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s14JoinedSequenceV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Separator"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsST7ElementRpzrlE6joined9separators14JoinedSequenceVyxGqd___tSTRd__AA_AAQZAARtd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Sequence, τ_1_0 : Sequence, τ_0_0.Element : Sequence, τ_1_0.Element == τ_0_0.Element.Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "lazy",
           "printedName": "lazy",
-          "declKind": "Var",
-          "usr": "s:STsE4lazys12LazySequenceVyxGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazySequence",
-              "printedName": "LazySequence<Self>",
-              "usr": "s:s12LazySequenceV",
+              "printedName": "LazySequence<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s12LazySequenceV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:STsE4lazys12LazySequenceVyxGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "LazySequence",
-                  "printedName": "LazySequence<Self>",
-                  "usr": "s:s12LazySequenceV",
+                  "printedName": "LazySequence<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Self"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s12LazySequenceV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:STsE4lazys12LazySequenceVyxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:STsE4lazys12LazySequenceVyxGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:STs8IteratorSTQzRszrlE04makeA0xyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self == Self.Iterator>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STs8IteratorSTQzRszrlE04makeA0xyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0 == τ_0_0.Iterator>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:STsE3mapySayqd__Gqd__7ElementQzKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[T]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> T",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> τ_1_0",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE3mapySayqd__Gqd__7ElementQzKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:STsE6filterySay7ElementQzGSbACKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Self.Element]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -79509,31 +86632,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE6filterySay7ElementQzGSbACKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:STsE19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -79545,11 +86666,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:STsE19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -79557,24 +86673,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:STsE19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:STsE19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "forEach",
           "printedName": "forEach(_:)",
-          "declKind": "Func",
-          "usr": "s:STsE7forEachyyy7ElementQzKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -79584,74 +86700,56 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> ()",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
+                  "kind": "TypeNominal",
                   "name": "Void",
-                  "printedName": "Void",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Void",
-                      "printedName": "()"
-                    }
-                  ]
+                  "printedName": "()"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE7forEachyyy7ElementQzKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "first",
           "printedName": "first(where:)",
-          "declKind": "Func",
-          "usr": "s:STsE5first5where7ElementQzSgSbADKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -79661,50 +86759,47 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE5first5where7ElementQzSgSbADKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(separator:maxSplits:omittingEmptySubsequences:)",
-          "declKind": "Func",
-          "usr": "s:STsSQ7ElementRpzrlE5split9separator9maxSplits25omittingEmptySubsequencesSay11SubSequenceQzGAB_SiSbtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.Element : Equatable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Self.SubSequence]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0.SubSequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.SubSequence"
+                  "printedName": "τ_0_0.SubSequence"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             },
             {
               "kind": "TypeNominal",
@@ -79720,43 +86815,40 @@
               "hasDefaultArg": true,
               "usr": "s:Sb"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSQ7ElementRpzrlE5split9separator9maxSplits25omittingEmptySubsequencesSay11SubSequenceQzGAB_SiSbtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Equatable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(maxSplits:omittingEmptySubsequences:whereSeparator:)",
-          "declKind": "Func",
-          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAEGSi_S2bADKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[AnySequence<Self.Element>]",
-              "usr": "s:Sa",
+              "printedName": "Array<AnySequence<τ_0_0.Element>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnySequence",
-                  "printedName": "AnySequence<Self.Element>",
-                  "usr": "s:s11AnySequenceV",
+                  "printedName": "AnySequence<τ_0_0.Element>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Element"
+                      "printedName": "τ_0_0.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s11AnySequenceV"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -79775,10 +86867,7 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -79788,45 +86877,42 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAEGSi_S2bADKXEtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.SubSequence == AnySequence<τ_0_0.Element>>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE6suffixyAESiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
-              "printedName": "AnySequence<Self.Element>",
-              "usr": "s:s11AnySequenceV",
+              "printedName": "AnySequence<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
@@ -79834,33 +86920,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE6suffixyAESiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.SubSequence == AnySequence<τ_0_0.Element>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE9dropFirstyAESiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
-              "printedName": "AnySequence<Self.Element>",
-              "usr": "s:s11AnySequenceV",
+              "printedName": "AnySequence<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
@@ -79868,33 +86953,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE9dropFirstyAESiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.SubSequence == AnySequence<τ_0_0.Element>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE8dropLastyAESiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
-              "printedName": "AnySequence<Self.Element>",
-              "usr": "s:s11AnySequenceV",
+              "printedName": "AnySequence<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
@@ -79902,43 +86986,37 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE8dropLastyAESiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.SubSequence == AnySequence<τ_0_0.Element>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE4drop5whileAESbADKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
-              "printedName": "AnySequence<Self.Element>",
-              "usr": "s:s11AnySequenceV",
+              "printedName": "AnySequence<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -79948,45 +87026,42 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE4drop5whileAESbADKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.SubSequence == AnySequence<τ_0_0.Element>>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(_:)",
-          "declKind": "Func",
-          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE6prefixyAESiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
-              "printedName": "AnySequence<Self.Element>",
-              "usr": "s:s11AnySequenceV",
+              "printedName": "AnySequence<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
@@ -79994,43 +87069,37 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE6prefixyAESiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.SubSequence == AnySequence<τ_0_0.Element>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE6prefix5whileAESbADKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
-              "printedName": "AnySequence<Self.Element>",
-              "usr": "s:s11AnySequenceV",
+              "printedName": "AnySequence<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80040,124 +87109,112 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE6prefix5whileAESbADKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.SubSequence == AnySequence<τ_0_0.Element>>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst()",
-          "declKind": "Func",
-          "usr": "s:STsE9dropFirst11SubSequenceQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE9dropFirst11SubSequenceQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast()",
-          "declKind": "Func",
-          "usr": "s:STsE8dropLast11SubSequenceQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE8dropLast11SubSequenceQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "enumerated",
           "printedName": "enumerated()",
-          "declKind": "Func",
-          "usr": "s:STsE10enumerateds18EnumeratedSequenceVyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "EnumeratedSequence",
-              "printedName": "EnumeratedSequence<Self>",
-              "usr": "s:s18EnumeratedSequenceV",
+              "printedName": "EnumeratedSequence<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Self"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s18EnumeratedSequenceV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE10enumerateds18EnumeratedSequenceVyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "min",
           "printedName": "min(by:)",
-          "declKind": "Func",
-          "usr": "s:STsE3min2by7ElementQzSgSbAD_ADtKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "WarnUnqualifiedAccess",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element, Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element, τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80168,60 +87225,59 @@
                 {
                   "kind": "TypeNominal",
                   "name": "Tuple",
-                  "printedName": "(Self.Element, Self.Element)",
+                  "printedName": "(τ_0_0.Element, τ_0_0.Element)",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Element"
+                      "printedName": "τ_0_0.Element"
                     },
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Element"
+                      "printedName": "τ_0_0.Element"
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE3min2by7ElementQzSgSbAD_ADtKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "WarnUnqualifiedAccess",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "max",
           "printedName": "max(by:)",
-          "declKind": "Func",
-          "usr": "s:STsE3max2by7ElementQzSgSbAD_ADtKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "WarnUnqualifiedAccess",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element, Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element, τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80232,96 +87288,97 @@
                 {
                   "kind": "TypeNominal",
                   "name": "Tuple",
-                  "printedName": "(Self.Element, Self.Element)",
+                  "printedName": "(τ_0_0.Element, τ_0_0.Element)",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Element"
+                      "printedName": "τ_0_0.Element"
                     },
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Element"
+                      "printedName": "τ_0_0.Element"
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE3max2by7ElementQzSgSbAD_ADtKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "WarnUnqualifiedAccess",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "min",
           "printedName": "min()",
-          "declKind": "Func",
-          "usr": "s:STsSL7ElementRpzrlE3minABSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.Element : Comparable>",
-          "declAttributes": [
-            "WarnUnqualifiedAccess",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSL7ElementRpzrlE3minABSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Comparable>",
+          "declAttributes": [
+            "WarnUnqualifiedAccess",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "max",
           "printedName": "max()",
-          "declKind": "Func",
-          "usr": "s:STsSL7ElementRpzrlE3maxABSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.Element : Comparable>",
-          "declAttributes": [
-            "WarnUnqualifiedAccess",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSL7ElementRpzrlE3maxABSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Comparable>",
+          "declAttributes": [
+            "WarnUnqualifiedAccess",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "starts",
           "printedName": "starts(with:by:)",
-          "declKind": "Func",
-          "usr": "s:STsE6starts4with2bySbqd___Sb7ElementQz_ADQyd__tKXEtKSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, PossiblePrefix where Self : Sequence, PossiblePrefix : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80332,15 +87389,12 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "PossiblePrefix"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element, PossiblePrefix.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element, τ_1_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80351,36 +87405,40 @@
                 {
                   "kind": "TypeNominal",
                   "name": "Tuple",
-                  "printedName": "(Self.Element, PossiblePrefix.Element)",
+                  "printedName": "(τ_0_0.Element, τ_1_0.Element)",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Element"
+                      "printedName": "τ_0_0.Element"
                     },
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "PossiblePrefix.Element"
+                      "printedName": "τ_1_0.Element"
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE6starts4with2bySbqd___Sb7ElementQz_ADQyd__tKXEtKSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Sequence, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "starts",
           "printedName": "starts(with:)",
-          "declKind": "Func",
-          "usr": "s:STsSQ7ElementRpzrlE6starts4withSbqd___tSTRd__AAQyd__ABRSlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, PossiblePrefix where Self : Sequence, PossiblePrefix : Sequence, Self.Element : Equatable, Self.Element == PossiblePrefix.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80391,24 +87449,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "PossiblePrefix"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSQ7ElementRpzrlE6starts4withSbqd___tSTRd__AAQyd__ABRSlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Sequence, τ_1_0 : Sequence, τ_0_0.Element : Equatable, τ_0_0.Element == τ_1_0.Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "elementsEqual",
           "printedName": "elementsEqual(_:by:)",
-          "declKind": "Func",
-          "usr": "s:STsE13elementsEqual_2bySbqd___Sb7ElementQz_ACQyd__tKXEtKSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, OtherSequence where Self : Sequence, OtherSequence : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80419,15 +87474,12 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "OtherSequence"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element, OtherSequence.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element, τ_1_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80438,36 +87490,40 @@
                 {
                   "kind": "TypeNominal",
                   "name": "Tuple",
-                  "printedName": "(Self.Element, OtherSequence.Element)",
+                  "printedName": "(τ_0_0.Element, τ_1_0.Element)",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Element"
+                      "printedName": "τ_0_0.Element"
                     },
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "OtherSequence.Element"
+                      "printedName": "τ_1_0.Element"
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE13elementsEqual_2bySbqd___Sb7ElementQz_ACQyd__tKXEtKSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Sequence, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "elementsEqual",
           "printedName": "elementsEqual(_:)",
-          "declKind": "Func",
-          "usr": "s:STsSQ7ElementRpzrlE13elementsEqualySbqd__STRd__AAQyd__ABRSlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, OtherSequence where Self : Sequence, OtherSequence : Sequence, Self.Element : Equatable, Self.Element == OtherSequence.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80478,24 +87534,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "OtherSequence"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSQ7ElementRpzrlE13elementsEqualySbqd__STRd__AAQyd__ABRSlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Sequence, τ_1_0 : Sequence, τ_0_0.Element : Equatable, τ_0_0.Element == τ_1_0.Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "lexicographicallyPrecedes",
           "printedName": "lexicographicallyPrecedes(_:by:)",
-          "declKind": "Func",
-          "usr": "s:STsE25lexicographicallyPrecedes_2bySbqd___Sb7ElementQz_ADtKXEtKSTRd__ACQyd__ADRSlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, OtherSequence where Self : Sequence, OtherSequence : Sequence, Self.Element == OtherSequence.Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80506,15 +87559,12 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "OtherSequence"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element, Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element, τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80525,36 +87575,40 @@
                 {
                   "kind": "TypeNominal",
                   "name": "Tuple",
-                  "printedName": "(Self.Element, Self.Element)",
+                  "printedName": "(τ_0_0.Element, τ_0_0.Element)",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Element"
+                      "printedName": "τ_0_0.Element"
                     },
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Element"
+                      "printedName": "τ_0_0.Element"
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE25lexicographicallyPrecedes_2bySbqd___Sb7ElementQz_ADtKXEtKSTRd__ACQyd__ADRSlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Sequence, τ_1_0 : Sequence, τ_0_0.Element == τ_1_0.Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "lexicographicallyPrecedes",
           "printedName": "lexicographicallyPrecedes(_:)",
-          "declKind": "Func",
-          "usr": "s:STsSL7ElementRpzrlE25lexicographicallyPrecedesySbqd__STRd__AAQyd__ABRSlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, OtherSequence where Self : Sequence, OtherSequence : Sequence, Self.Element : Comparable, Self.Element == OtherSequence.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80565,24 +87619,21 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "OtherSequence"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSL7ElementRpzrlE25lexicographicallyPrecedesySbqd__STRd__AAQyd__ABRSlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Sequence, τ_1_0 : Sequence, τ_0_0.Element : Comparable, τ_0_0.Element == τ_1_0.Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(where:)",
-          "declKind": "Func",
-          "usr": "s:STsE8contains5whereS2b7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80593,10 +87644,7 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80606,34 +87654,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE8contains5whereS2b7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "allSatisfy",
           "printedName": "allSatisfy(_:)",
-          "declKind": "Func",
-          "usr": "s:STsE10allSatisfyyS2b7ElementQzKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80644,10 +87687,7 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80657,32 +87697,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE10allSatisfyyS2b7ElementQzKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:STsSQ7ElementRpzrlE8containsySbABF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.Element : Equatable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80693,101 +87730,137 @@
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Element"
+              "printedName": "τ_0_0.Element"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSQ7ElementRpzrlE8containsySbABF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Equatable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
+          "name": "count",
+          "printedName": "count(where:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0.Element) throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE5count5whereSiSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
           "name": "reduce",
           "printedName": "reduce(_:_:)",
-          "declKind": "Func",
-          "usr": "s:STsE6reduceyqd__qd___qd__qd___7ElementQztKXEtKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Result where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Result"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Result"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Result, Self.Element) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_1_0, τ_0_0.Element) throws -> τ_1_0",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Result"
+                  "printedName": "τ_1_0"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "Tuple",
-                  "printedName": "(Result, Self.Element)",
+                  "printedName": "(τ_1_0, τ_0_0.Element)",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Result"
+                      "printedName": "τ_1_0"
                     },
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Element"
+                      "printedName": "τ_0_0.Element"
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE6reduceyqd__qd___qd__qd___7ElementQztKXEtKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "reduce",
           "printedName": "reduce(into:_:)",
-          "declKind": "Func",
-          "usr": "s:STsE6reduce4into_qd__qd___yqd__z_7ElementQztKXEtKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Result where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Result"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Result"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(inout Result, Self.Element) throws -> ()",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(inout τ_1_0, τ_0_0.Element) throws -> ()",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80797,237 +87870,218 @@
                 {
                   "kind": "TypeNominal",
                   "name": "Tuple",
-                  "printedName": "(inout Result, Self.Element)",
+                  "printedName": "(inout τ_1_0, τ_0_0.Element)",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "InOut",
-                      "printedName": "inout Result"
+                      "printedName": "inout τ_1_0"
                     },
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Element"
+                      "printedName": "τ_0_0.Element"
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE6reduce4into_qd__qd___yqd__z_7ElementQztKXEtKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "reversed",
           "printedName": "reversed()",
-          "declKind": "Func",
-          "usr": "s:STsE8reversedSay7ElementQzGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Self.Element]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE8reversedSay7ElementQzGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "flatMap",
           "printedName": "flatMap(_:)",
-          "declKind": "Func",
-          "usr": "s:STsE7flatMapySay7ElementQyd__Gqd__ABQzKXEKSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, SegmentOfResult where Self : Sequence, SegmentOfResult : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[SegmentOfResult.Element]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_1_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "SegmentOfResult.Element"
+                  "printedName": "τ_1_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> SegmentOfResult",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> τ_1_0",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "SegmentOfResult"
+                  "printedName": "τ_1_0"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE7flatMapySay7ElementQyd__Gqd__ABQzKXEKSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Sequence, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "compactMap",
           "printedName": "compactMap(_:)",
-          "declKind": "Func",
-          "usr": "s:STsE10compactMapySayqd__Gqd__Sg7ElementQzKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, ElementOfResult where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[ElementOfResult]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "ElementOfResult"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> ElementOfResult?",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Optional<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "ElementOfResult?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<τ_1_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "ElementOfResult"
+                      "printedName": "τ_1_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE10compactMapySayqd__Gqd__Sg7ElementQzKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "sorted",
           "printedName": "sorted()",
-          "declKind": "Func",
-          "usr": "s:STsSL7ElementRpzrlE6sortedSayABGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.Element : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Self.Element]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSL7ElementRpzrlE6sortedSayABGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "sorted",
           "printedName": "sorted(by:)",
-          "declKind": "Func",
-          "usr": "s:STsE6sorted2bySay7ElementQzGSbAD_ADtKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Self.Element]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element, Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element, τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -81038,37 +88092,40 @@
                 {
                   "kind": "TypeNominal",
                   "name": "Tuple",
-                  "printedName": "(Self.Element, Self.Element)",
+                  "printedName": "(τ_0_0.Element, τ_0_0.Element)",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Element"
+                      "printedName": "τ_0_0.Element"
                     },
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
-                      "printedName": "Self.Element"
+                      "printedName": "τ_0_0.Element"
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE6sorted2bySay7ElementQzGSbAD_ADtKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "joined",
           "printedName": "joined(separator:)",
-          "declKind": "Func",
-          "usr": "s:STsSy7ElementRpzrlE6joined9separatorS2S_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.Element : StringProtocol>",
-          "declAttributes": [
-            "Specialize",
-            "Specialize"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -81083,309 +88140,252 @@
               "hasDefaultArg": true,
               "usr": "s:SS"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSy7ElementRpzrlE6joined9separatorS2S_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element : StringProtocol>",
+          "declAttributes": [
+            "Specialize",
+            "Specialize"
           ]
         },
         {
           "kind": "Function",
           "name": "flatMap",
           "printedName": "flatMap(_:)",
-          "declKind": "Func",
-          "usr": "s:STsE7flatMapySayqd__Gqd__Sg7ElementQzKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, ElementOfResult where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[ElementOfResult]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "ElementOfResult"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> ElementOfResult?",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Optional<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "ElementOfResult?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<τ_1_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "ElementOfResult"
+                      "printedName": "τ_1_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "flatMap",
-          "printedName": "flatMap(_:)",
+          ],
           "declKind": "Func",
-          "usr": "s:STsE7flatMapySaySSGSS7ElementQzKXEKF",
-          "location": "",
+          "usr": "s:STsE7flatMapySayqd__Gqd__Sg7ElementQzKXEKlF",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Sequence>",
+          "deprecated": true,
           "declAttributes": [
             "Rethrows",
             "Available"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "[String]",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Element) throws -> String",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
+          "throwing": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:ST",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0.Element == τ_0_0.Iterator.Element, τ_0_0.Iterator : IteratorProtocol, τ_0_0.SubSequence : Sequence, τ_0_0.SubSequence == τ_0_0.SubSequence.SubSequence, τ_0_0.Iterator.Element == τ_0_0.SubSequence.Element, τ_0_0.SubSequence.Element == τ_0_0.SubSequence.Iterator.Element>"
     },
     {
       "kind": "TypeDecl",
       "name": "IteratorSequence",
       "printedName": "IteratorSequence",
-      "declKind": "Struct",
-      "usr": "s:s16IteratorSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : IteratorProtocol>",
-      "conformingProtocols": [
-        "IteratorProtocol",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s16IteratorSequenceVyAByxGxcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : IteratorProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "kind": "Var",
+          "name": "_base",
+          "printedName": "_base",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "IteratorSequence",
-              "printedName": "IteratorSequence<Base>",
-              "usr": "s:s16IteratorSequenceV",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Base"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s16IteratorSequenceV5_basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : IteratorProtocol>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s16IteratorSequenceV5_basexvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "IteratorSequence",
+              "printedName": "IteratorSequence<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s16IteratorSequenceV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Base"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s16IteratorSequenceVyAByxGxcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : IteratorProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s16IteratorSequenceV4next7ElementQzSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : IteratorProtocol>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Base.Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Base.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s16IteratorSequenceV7Elementa",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s16IteratorSequenceV4next7ElementQzSgyF",
           "moduleName": "Swift",
-          "genericSig": "<Base where Base : IteratorProtocol>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s16IteratorSequenceV0A0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : IteratorProtocol>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "IteratorSequence",
-              "printedName": "IteratorSequence<Base>",
-              "usr": "s:s16IteratorSequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s16IteratorSequenceV03SubB0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : IteratorProtocol>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnySequence",
-              "printedName": "AnySequence<Base.Element>",
-              "usr": "s:s11AnySequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Element"
-                }
-              ]
-            }
-          ]
+          "genericSig": "<τ_0_0 where τ_0_0 : IteratorProtocol>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s16IteratorSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : IteratorProtocol>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol",
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "_SequenceWrapper",
       "printedName": "_SequenceWrapper",
-      "declKind": "Protocol",
-      "usr": "s:s16_SequenceWrapperP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Sequence, Self.Base : Sequence, Self.Element == Self.Base.Element>",
-      "conformingProtocols": [
-        "Sequence"
-      ],
-      "declAttributes": [
-        "ShowInInterface"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Base",
+          "printedName": "Base",
+          "declKind": "AssociatedType",
+          "usr": "s:s16_SequenceWrapperP4BaseQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Iterator",
+          "printedName": "Iterator",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Base.Iterator"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:s16_SequenceWrapperP8IteratorQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Base.SubSequence"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:s16_SequenceWrapperP03SubA0Qa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s16_SequenceWrapperPsE19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -81397,11 +88397,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s16_SequenceWrapperPsE19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : _SequenceWrapper>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -81409,122 +88404,110 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s16_SequenceWrapperPsE19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : _SequenceWrapper>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s16_SequenceWrapperPsE19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPs4Base_8IteratorQZADRtzrlE04makeD0AFyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper, Self.Iterator == Self.Base.Iterator>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.Iterator"
+              "printedName": "τ_0_0.Iterator"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPs4Base_8IteratorQZADRtzrlE04makeD0AFyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _SequenceWrapper, τ_0_0.Iterator == τ_0_0.Base.Iterator>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPsE3mapySayqd__Gqd__7ElementQzKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : _SequenceWrapper>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[T]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> T",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> τ_1_0",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPsE3mapySayqd__Gqd__7ElementQzKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : _SequenceWrapper>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPsE6filterySay7ElementQzGSbAEKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Self.Element]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -81534,34 +88517,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPsE6filterySay7ElementQzGSbAEKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _SequenceWrapper>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "forEach",
           "printedName": "forEach(_:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPsE7forEachyyy7ElementQzKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -81571,56 +88549,43 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> ()",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
+                  "kind": "TypeNominal",
                   "name": "Void",
-                  "printedName": "Void",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Void",
-                      "printedName": "()"
-                    }
-                  ]
+                  "printedName": "()"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPsE7forEachyyy7ElementQzKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _SequenceWrapper>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE9dropFirstyAFSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
@@ -81628,25 +88593,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE9dropFirstyAFSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _SequenceWrapper, τ_0_0.SubSequence == τ_0_0.Base.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE8dropLastyAFSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
@@ -81654,25 +88618,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE8dropLastyAFSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _SequenceWrapper, τ_0_0.SubSequence == τ_0_0.Base.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(_:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE6prefixyAFSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
@@ -81680,25 +88643,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE6prefixyAFSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _SequenceWrapper, τ_0_0.SubSequence == τ_0_0.Base.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE6suffixyAFSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeNominal",
@@ -81706,35 +88668,29 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE6suffixyAFSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _SequenceWrapper, τ_0_0.SubSequence == τ_0_0.Base.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE4drop5whileAFSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -81744,47 +88700,39 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE4drop5whileAFSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _SequenceWrapper, τ_0_0.SubSequence == τ_0_0.Base.SubSequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE6prefix5whileAFSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
-              "printedName": "Self.SubSequence"
+              "printedName": "τ_0_0.SubSequence"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -81794,47 +88742,42 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE6prefix5whileAFSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _SequenceWrapper, τ_0_0.SubSequence == τ_0_0.Base.SubSequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(maxSplits:omittingEmptySubsequences:whereSeparator:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAFGSi_S2b7ElementQzKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Self.SubSequence]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0.SubSequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.SubSequence"
+                  "printedName": "τ_0_0.SubSequence"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -81851,10 +88794,7 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -81864,31 +88804,2232 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAFGSi_S2b7ElementQzKXEtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _SequenceWrapper, τ_0_0.SubSequence == τ_0_0.Base.SubSequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s16_SequenceWrapperP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : Sequence, τ_0_0.Base : Sequence, τ_0_0.Element == τ_0_0.Base.Element>",
+      "declAttributes": [
+        "ShowInInterface"
+      ],
+      "conformingProtocols": [
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Set",
       "printedName": "Set",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_variant",
+          "printedName": "_variant",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "_Variant",
+              "printedName": "Set<τ_0_0>._Variant",
+              "usr": "s:Sh8_VariantO"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_Variant",
+                  "printedName": "Set<τ_0_0>._Variant",
+                  "usr": "s:Sh8_VariantO"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh8_variantSh8_VariantOyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh8_variantSh8_VariantOyx_Gvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(minimumCapacity:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sh15minimumCapacityShyxGSi_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>"
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:ShsSERzrlE6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Encodable, τ_0_0 : Hashable>",
+          "throwing": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:ShsSeRzrlE4fromShyxGs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Decodable, τ_0_0 : Hashable>",
+          "throwing": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(arrayLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sa"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sh12arrayLiteralShyxGxd_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "makeIterator",
+          "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Iterator",
+              "printedName": "Set<τ_0_0>.Iterator",
+              "usr": "s:Sh8IteratorV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh12makeIteratorSh0B0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "contains",
+          "printedName": "contains(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh8containsySbxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "filter",
+          "printedName": "filter(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(τ_0_0) throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh6filteryShyxGSbxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Rethrows",
+            "Available",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Set<τ_0_0>.Index",
+              "usr": "s:Sh5IndexV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Set<τ_0_0>.Index",
+                  "usr": "s:Sh5IndexV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh10startIndexSh0B0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh10startIndexSh0B0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Set<τ_0_0>.Index",
+              "usr": "s:Sh5IndexV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Set<τ_0_0>.Index",
+                  "usr": "s:Sh5IndexV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh8endIndexSh0B0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh8endIndexSh0B0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Set<τ_0_0>.Index",
+              "usr": "s:Sh5IndexV"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:ShyxSh5IndexVyx_Gcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Set<τ_0_0>.Index",
+              "usr": "s:Sh5IndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Set<τ_0_0>.Index",
+              "usr": "s:Sh5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh5index5afterSh5IndexVyx_GAE_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Set<τ_0_0>.Index",
+              "usr": "s:Sh5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh9formIndex5afterySh0B0Vyx_Gz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "firstIndex",
+          "printedName": "firstIndex(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Set<τ_0_0>.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Set<τ_0_0>.Index",
+                  "usr": "s:Sh5IndexV"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh10firstIndex2ofSh0B0Vyx_GSgx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "count",
+          "printedName": "count",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isEmpty",
+          "printedName": "isEmpty",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "first",
+          "printedName": "first",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh5firstxSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh5firstxSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh2eeoiySbShyxG_ABtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "hash",
+          "printedName": "hash(into:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Hasher",
+              "printedName": "Hasher",
+              "usr": "s:s6HasherV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "hashValue",
+          "printedName": "hashValue",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+              "implicit": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Function",
+          "name": "insert",
+          "printedName": "insert(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(inserted: Bool, memberAfterInsert: τ_0_0)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh6insertySb8inserted_x17memberAfterInserttxnF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "update",
+          "printedName": "update(with:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh6update4withxSgxn_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "remove",
+          "printedName": "remove(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh6removeyxSgxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "remove",
+          "printedName": "remove(at:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Set<τ_0_0>.Index",
+              "usr": "s:Sh5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh6remove2atxSh5IndexVyx_G_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "removeAll",
+          "printedName": "removeAll(keepingCapacity:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "hasDefaultArg": true,
+              "usr": "s:Sb"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh9removeAll15keepingCapacityySb_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "removeFirst",
+          "printedName": "removeFirst()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh11removeFirstxyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:S2hyxGycfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:ShyShyxGqd__nc7ElementQyd__RszSTRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Hashable, τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isSubset",
+          "printedName": "isSubset(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh8isSubset2ofSbqd___t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Hashable, τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isStrictSubset",
+          "printedName": "isStrictSubset(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh14isStrictSubset2ofSbqd___t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Hashable, τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isSuperset",
+          "printedName": "isSuperset(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh10isSuperset2ofSbqd__n_t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Hashable, τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isStrictSuperset",
+          "printedName": "isStrictSuperset(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh16isStrictSuperset2ofSbqd___t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Hashable, τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isDisjoint",
+          "printedName": "isDisjoint(with:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh10isDisjoint4withSbqd___t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Hashable, τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "union",
+          "printedName": "union(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh5unionyShyxGqd__n7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Hashable, τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formUnion",
+          "printedName": "formUnion(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh9formUnionyyqd__n7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Hashable, τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "subtracting",
+          "printedName": "subtracting(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh11subtractingyShyxGqd__7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Hashable, τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "subtract",
+          "printedName": "subtract(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh8subtractyyqd__7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Hashable, τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "intersection",
+          "printedName": "intersection(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh12intersectionyShyxGqd__7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Hashable, τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIntersection",
+          "printedName": "formIntersection(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh16formIntersectionyyqd__7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Hashable, τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "symmetricDifference",
+          "printedName": "symmetricDifference(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh19symmetricDifferenceyShyxGqd__n7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Hashable, τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formSymmetricDifference",
+          "printedName": "formSymmetricDifference(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh23formSymmetricDifferenceyyqd__n7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : Hashable, τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Var",
+          "name": "description",
+          "printedName": "description",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh11descriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "subtract",
+          "printedName": "subtract(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh8subtractyyShyxGF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "isSubset",
+          "printedName": "isSubset(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh8isSubset2ofSbShyxG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isSuperset",
+          "printedName": "isSuperset(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh10isSuperset2ofSbShyxG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isDisjoint",
+          "printedName": "isDisjoint(with:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh10isDisjoint4withSbShyxG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "subtracting",
+          "printedName": "subtracting(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh11subtractingyShyxGABF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isStrictSuperset",
+          "printedName": "isStrictSuperset(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh16isStrictSuperset2ofSbShyxG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isStrictSubset",
+          "printedName": "isStrictSubset(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh14isStrictSubset2ofSbShyxG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "intersection",
+          "printedName": "intersection(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh12intersectionyShyxGABF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formSymmetricDifference",
+          "printedName": "formSymmetricDifference(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sh"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh23formSymmetricDifferenceyyShyxGnF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "Index",
+          "printedName": "Index",
+          "children": [
+            {
+              "kind": "Var",
+              "name": "_variant",
+              "printedName": "_variant",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_Variant",
+                  "printedName": "Set<τ_0_0>.Index._Variant",
+                  "usr": "s:Sh5IndexV8_VariantO"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_Variant",
+                      "printedName": "Set<τ_0_0>.Index._Variant",
+                      "usr": "s:Sh5IndexV8_VariantO"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Sh5IndexV8_variantAB8_VariantOyx__Gvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Sh5IndexV8_variantAB8_VariantOyx__Gvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Set<τ_0_0>.Index",
+                  "usr": "s:Sh5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Set<τ_0_0>.Index",
+                  "usr": "s:Sh5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Sh5IndexV2eeoiySbAByx_G_ADtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Set<τ_0_0>.Index",
+                  "usr": "s:Sh5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Set<τ_0_0>.Index",
+                  "usr": "s:Sh5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Sh5IndexV1loiySbAByx_G_ADtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "hash",
+              "printedName": "hash(into:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Hasher",
+                  "printedName": "Hasher",
+                  "usr": "s:s6HasherV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Sh5IndexV4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>"
+            },
+            {
+              "kind": "Var",
+              "name": "hashValue",
+              "printedName": "hashValue",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Sh5IndexV9hashValueSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+                  "implicit": true
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Sh5IndexV9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:Sh5IndexV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "Equatable",
+            "Comparable",
+            "Hashable"
+          ]
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "Iterator",
+          "printedName": "Iterator",
+          "children": [
+            {
+              "kind": "Var",
+              "name": "_variant",
+              "printedName": "_variant",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_Variant",
+                  "printedName": "Set<τ_0_0>.Iterator._Variant",
+                  "usr": "s:Sh8IteratorV8_VariantO"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_Variant",
+                      "printedName": "Set<τ_0_0>.Iterator._Variant",
+                      "usr": "s:Sh8IteratorV8_VariantO"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Sh8IteratorV8_variantAB8_VariantOyx__Gvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Sh8IteratorV8_variantAB8_VariantOyx__Gvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Function",
+              "name": "next",
+              "printedName": "next()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Sh8IteratorV4nextxSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
+              ],
+              "mutating": true
+            },
+            {
+              "kind": "Var",
+              "name": "customMirror",
+              "printedName": "customMirror",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Mirror",
+                      "printedName": "Mirror",
+                      "usr": "s:s6MirrorV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Sh8IteratorV12customMirrors0C0Vvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Sh8IteratorV12customMirrors0C0Vvp",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:Sh8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "CustomReflectable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "customMirror",
+          "printedName": "customMirror",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Mirror",
+              "printedName": "Mirror",
+              "usr": "s:s6MirrorV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh12customMirrors0B0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh12customMirrors0B0Vvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "popFirst",
+          "printedName": "popFirst()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh8popFirstxSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Var",
+          "name": "capacity",
+          "printedName": "capacity",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh8capacitySivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh8capacitySivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "reserveCapacity",
+          "printedName": "reserveCapacity(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh15reserveCapacityyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "insert",
+          "printedName": "insert(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(inserted: Bool, memberAfterInsert: τ_1_0)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Shss11AnyHashableVRszrlE6insertySb8inserted_qd__17memberAfterInserttqd__nSHRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == AnyHashable, τ_1_0 : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "update",
+          "printedName": "update(with:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_1_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Shss11AnyHashableVRszrlE6update4withqd__Sgqd__n_tSHRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == AnyHashable, τ_1_0 : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "remove",
+          "printedName": "remove(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_1_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Shss11AnyHashableVRszrlE6removeyqd__Sgqd__SHRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == AnyHashable, τ_1_0 : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        }
+      ],
       "declKind": "Struct",
       "usr": "s:Sh",
-      "location": "",
       "moduleName": "Swift",
-      "genericSig": "<Element where Element : Hashable>",
+      "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "Encodable",
         "Decodable",
@@ -81902,24 +91043,4082 @@
         "CustomStringConvertible",
         "CustomDebugStringConvertible",
         "CustomReflectable"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "SetAlgebra",
+      "printedName": "SetAlgebra",
+      "children": [
+        {
+          "kind": "AssociatedType",
+          "name": "Element",
+          "printedName": "Element",
+          "declKind": "AssociatedType",
+          "usr": "s:s10SetAlgebraP7ElementQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s10SetAlgebraPxycfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "contains",
+          "printedName": "contains(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP8containsySb7ElementQzF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "union",
+          "printedName": "union(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP5unionyxxnF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "intersection",
+          "printedName": "intersection(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP12intersectionyxxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "symmetricDifference",
+          "printedName": "symmetricDifference(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP19symmetricDifferenceyxxnF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "insert",
+          "printedName": "insert(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(inserted: Bool, memberAfterInsert: τ_0_0.Element)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP6insertySb8inserted_7ElementQz17memberAfterInserttAFnF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "protocolReq": true,
+          "declAttributes": [
+            "DiscardableResult"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "remove",
+          "printedName": "remove(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0.Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP6removey7ElementQzSgAEF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "protocolReq": true,
+          "declAttributes": [
+            "DiscardableResult"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "update",
+          "printedName": "update(with:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0.Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP6update4with7ElementQzSgAFn_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "protocolReq": true,
+          "declAttributes": [
+            "DiscardableResult"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "formUnion",
+          "printedName": "formUnion(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP9formUnionyyxnF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "protocolReq": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "formIntersection",
+          "printedName": "formIntersection(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP16formIntersectionyyxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "protocolReq": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "formSymmetricDifference",
+          "printedName": "formSymmetricDifference(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP23formSymmetricDifferenceyyxnF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "protocolReq": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "subtracting",
+          "printedName": "subtracting(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP11subtractingyxxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "isSubset",
+          "printedName": "isSubset(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP8isSubset2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "isDisjoint",
+          "printedName": "isDisjoint(with:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP10isDisjoint4withSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "isSuperset",
+          "printedName": "isSuperset(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP10isSuperset2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "isEmpty",
+          "printedName": "isEmpty",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10SetAlgebraP7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10SetAlgebraP7isEmptySbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s10SetAlgebraPyxqd__ncSTRd__7ElementQyd__ACRtzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : SetAlgebra, τ_1_0 : Sequence, τ_0_0.Element == τ_1_0.Element>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "subtract",
+          "printedName": "subtract(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP8subtractyyxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "protocolReq": true,
+          "mutating": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s10SetAlgebraPsEyxqd__ncSTRd__7ElementQyd__ACRtzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : SetAlgebra, τ_1_0 : Sequence, τ_0_0.Element == τ_1_0.Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "subtract",
+          "printedName": "subtract(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraPsE8subtractyyxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "isSubset",
+          "printedName": "isSubset(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraPsE8isSubset2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isSuperset",
+          "printedName": "isSuperset(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraPsE10isSuperset2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isDisjoint",
+          "printedName": "isDisjoint(with:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraPsE10isDisjoint4withSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "subtracting",
+          "printedName": "subtracting(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraPsE11subtractingyxxF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isEmpty",
+          "printedName": "isEmpty",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10SetAlgebraPsE7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10SetAlgebraPsE7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isStrictSuperset",
+          "printedName": "isStrictSuperset(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraPsE16isStrictSuperset2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isStrictSubset",
+          "printedName": "isStrictSubset(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraPsE14isStrictSubset2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(arrayLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<τ_0_0.Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ],
+              "usr": "s:Sa"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s10SetAlgebraPs7ElementQz012ArrayLiteralC0RtzrlE05arrayE0xAFd_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : SetAlgebra, τ_0_0.ArrayLiteralElement == τ_0_0.Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        }
       ],
+      "declKind": "Protocol",
+      "usr": "s:s10SetAlgebraP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : Equatable, τ_0_0 : ExpressibleByArrayLiteral>",
+      "conformingProtocols": [
+        "Equatable",
+        "ExpressibleByArrayLiteral"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Slice",
+      "printedName": "Slice",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_startIndex",
+          "printedName": "_startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5SliceV11_startIndex0C0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5SliceV11_startIndex0C0Qzvs",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5SliceV11_startIndex0C0Qzvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_endIndex",
+          "printedName": "_endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5SliceV9_endIndex0C0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5SliceV9_endIndex0C0Qzvs",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5SliceV9_endIndex0C0Qzvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_base",
+          "printedName": "_base",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5SliceV5_basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5SliceV5_basexvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 2,
+          "hasStorage": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(base:bounds:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5SliceV4base6boundsAByxGx_Sny5IndexQzGtcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "base",
+          "printedName": "base",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5SliceV4basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5SliceV4basexvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5SliceV10startIndex0C0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5SliceV10startIndex0C0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5SliceV8endIndex0C0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5SliceV8endIndex0C0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s5SliceVy7ElementQz5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s5SliceVyAByxGSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "indices",
+          "printedName": "indices",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Indices"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Indices"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5SliceV7indices7IndicesQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5SliceV7indices7IndicesQzvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceV5index5after5IndexQzAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceV9formIndex5aftery0C0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceV5index_8offsetBy5IndexQzAF_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:limitedBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceV5index_8offsetBy07limitedD05IndexQzSgAG_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(from:to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceV8distance4from2toSi5IndexQz_AGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSKRzrlE5index6before5IndexQzAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSKRzrlE9formIndex6beforey0C0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s5SliceVsSMRzrlEy7ElementQz5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : MutableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s5SliceVsSMRzrlEyAByxGSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : MutableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5SliceVsSmRzrlEAByxGycfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(repeating:count:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5SliceVsSmRzrlE9repeating5countAByxG7ElementQz_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5SliceVsSmRzrlEyAByxGqd__cSTRd__7ElementQyd__ADRtzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RangeReplaceableCollection, τ_1_0 : Sequence, τ_0_0.Element == τ_1_0.Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "replaceSubrange",
+          "printedName": "replaceSubrange(_:with:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSmRzrlE15replaceSubrange_4withySny5IndexQzG_qd__tSlRd__7ElementQyd__AHRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RangeReplaceableCollection, τ_1_0 : Collection, τ_0_0.Element == τ_1_0.Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "insert",
+          "printedName": "insert(_:at:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSmRzrlE6insert_2aty7ElementQz_5IndexQztF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "insert",
+          "printedName": "insert(contentsOf:at:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSmRzrlE6insert10contentsOf2atyqd___5IndexQztSlRd__7ElementQyd__AHRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : RangeReplaceableCollection, τ_1_0 : Collection, τ_0_0.Element == τ_1_0.Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "remove",
+          "printedName": "remove(at:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSmRzrlE6remove2at7ElementQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "removeSubrange",
+          "printedName": "removeSubrange(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSmRzrlE14removeSubrangeyySny5IndexQzGF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "replaceSubrange",
+          "printedName": "replaceSubrange(_:with:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSKRzSmRzrlE15replaceSubrange_4withySny5IndexSlQzG_qd__tSlRd__7ElementQyd__AHSTRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BidirectionalCollection, τ_0_0 : RangeReplaceableCollection, τ_1_0 : Collection, τ_0_0.Element == τ_1_0.Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "insert",
+          "printedName": "insert(_:at:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSKRzSmRzrlE6insert_2aty7ElementSTQz_5IndexSlQztF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "insert",
+          "printedName": "insert(contentsOf:at:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSKRzSmRzrlE6insert10contentsOf2atyqd___5IndexSlQztSlRd__7ElementQyd__AHSTRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : BidirectionalCollection, τ_0_0 : RangeReplaceableCollection, τ_1_0 : Collection, τ_0_0.Element == τ_1_0.Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "remove",
+          "printedName": "remove(at:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Index"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSKRzSmRzrlE6remove2at7ElementSTQz5IndexSlQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "removeSubrange",
+          "printedName": "removeSubrange(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<τ_0_0.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSKRzSmRzrlE14removeSubrangeyySny5IndexSlQzGF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BidirectionalCollection, τ_0_0 : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s5SliceV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
       "declAttributes": [
         "FixedLayout"
       ],
+      "conformingProtocols": [
+        "LazySequenceProtocol",
+        "LazyCollectionProtocol",
+        "Collection",
+        "Sequence",
+        "BidirectionalCollection",
+        "MutableCollection",
+        "RandomAccessCollection",
+        "RangeReplaceableCollection"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "StaticString",
+      "printedName": "StaticString",
       "children": [
         {
+          "kind": "Var",
+          "name": "_startPtrOrData",
+          "printedName": "_startPtrOrData",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "BuiltinInteger",
+              "printedName": "Builtin.Word"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Word"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV15_startPtrOrDataBwvg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV15_startPtrOrDataBwvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_utf8CodeUnitCount",
+          "printedName": "_utf8CodeUnitCount",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "BuiltinInteger",
+              "printedName": "Builtin.Word"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Word"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV18_utf8CodeUnitCountBwvg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV18_utf8CodeUnitCountBwvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_flags",
+          "printedName": "_flags",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "BuiltinInteger",
+              "printedName": "Builtin.Int8"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinInteger",
+                  "printedName": "Builtin.Int8"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV6_flagsBi8_vg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV6_flagsBi8_vp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 2,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "utf8Start",
+          "printedName": "utf8Start",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafePointer",
+              "printedName": "UnsafePointer<UInt8>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt8",
+                  "printedName": "UInt8",
+                  "usr": "s:s5UInt8V"
+                }
+              ],
+              "usr": "s:SP"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafePointer",
+                  "printedName": "UnsafePointer<UInt8>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt8",
+                      "printedName": "UInt8",
+                      "usr": "s:s5UInt8V"
+                    }
+                  ],
+                  "usr": "s:SP"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV9utf8StartSPys5UInt8VGvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV9utf8StartSPys5UInt8VGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "unicodeScalar",
+          "printedName": "unicodeScalar",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Scalar",
+              "printedName": "Unicode.Scalar",
+              "usr": "s:s7UnicodeO6ScalarV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Scalar",
+                  "printedName": "Unicode.Scalar",
+                  "usr": "s:s7UnicodeO6ScalarV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV13unicodeScalars7UnicodeO0D0Vvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV13unicodeScalars7UnicodeO0D0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "utf8CodeUnitCount",
+          "printedName": "utf8CodeUnitCount",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV17utf8CodeUnitCountSivg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV17utf8CodeUnitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "hasPointerRepresentation",
+          "printedName": "hasPointerRepresentation",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV24hasPointerRepresentationSbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV24hasPointerRepresentationSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isASCII",
+          "printedName": "isASCII",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV7isASCIISbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV7isASCIISbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "withUTF8Buffer",
+          "printedName": "withUTF8Buffer(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafeBufferPointer<UInt8>) -> τ_0_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeBufferPointer",
+                  "printedName": "UnsafeBufferPointer<UInt8>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt8",
+                      "printedName": "UInt8",
+                      "usr": "s:s5UInt8V"
+                    }
+                  ],
+                  "usr": "s:SR"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s12StaticStringV14withUTF8BufferyxxSRys5UInt8VGXElF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "StaticString",
+              "printedName": "StaticString",
+              "usr": "s:s12StaticStringV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s12StaticStringVABycfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(unicodeScalar:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "StaticString",
+              "printedName": "StaticString",
+              "usr": "s:s12StaticStringV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "BuiltinInteger",
+              "printedName": "Builtin.Int32"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s12StaticStringV13unicodeScalarABBi32__tcfc",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "Transparent",
+            "UsableFromInline"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(unicodeScalarLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "StaticString",
+              "printedName": "StaticString",
+              "usr": "s:s12StaticStringV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "StaticString",
+              "printedName": "StaticString",
+              "usr": "s:s12StaticStringV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s12StaticStringV20unicodeScalarLiteralA2B_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent",
+            "Effects"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(extendedGraphemeClusterLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "StaticString",
+              "printedName": "StaticString",
+              "usr": "s:s12StaticStringV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "StaticString",
+              "printedName": "StaticString",
+              "usr": "s:s12StaticStringV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s12StaticStringV30extendedGraphemeClusterLiteralA2B_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent",
+            "Effects"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(stringLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "StaticString",
+              "printedName": "StaticString",
+              "usr": "s:s12StaticStringV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "StaticString",
+              "printedName": "StaticString",
+              "usr": "s:s12StaticStringV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s12StaticStringV13stringLiteralA2B_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent",
+            "Effects"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "description",
+          "printedName": "description",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV11descriptionSSvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV11descriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV16debugDescriptionSSvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "customMirror",
+          "printedName": "customMirror",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Mirror",
+              "printedName": "Mirror",
+              "usr": "s:s6MirrorV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV12customMirrors0D0Vvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV12customMirrors0D0Vvp",
+          "moduleName": "Swift"
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s12StaticStringV",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "CustomReflectable",
+        "_ExpressibleByBuiltinExtendedGraphemeClusterLiteral",
+        "_ExpressibleByBuiltinStringLiteral",
+        "ExpressibleByUnicodeScalarLiteral",
+        "ExpressibleByExtendedGraphemeClusterLiteral",
+        "ExpressibleByStringLiteral",
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible",
+        "_ExpressibleByBuiltinUnicodeScalarLiteral"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Strideable",
+      "printedName": "Strideable",
+      "children": [
+        {
+          "kind": "AssociatedType",
+          "name": "Stride",
+          "printedName": "Stride",
+          "declKind": "AssociatedType",
+          "usr": "s:Sx6StrideQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Stride"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sx8distance2to6StrideQzx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "advanced",
+          "printedName": "advanced(by:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Stride"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sx8advanced2byx6StrideQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "...",
+          "printedName": "...(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SN"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SxsSZ6StrideRpzrlE3zzzoiySNyxGx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable, τ_0_0.Stride : SignedInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Stride"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sxss8_PointerRzrlE1poiyxx_6StrideQztFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _Pointer>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Stride"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sxss8_PointerRzrlE1poiyx6StrideQz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _Pointer>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Stride"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sxss8_PointerRzrlE1soiyxx_6StrideQztFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _Pointer>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Stride"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sxss8_PointerRzrlE1soiy6StrideQzx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _Pointer>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Stride"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sxss8_PointerRzrlE2peoiyyxz_6StrideQztFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _Pointer>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Stride"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sxss8_PointerRzrlE2seoiyyxz_6StrideQztFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _Pointer>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SxsE1loiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SxsE2eeoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:Sx",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : Comparable, τ_0_0.Stride : Comparable, τ_0_0.Stride : SignedNumeric>",
+      "conformingProtocols": [
+        "Comparable",
+        "Equatable"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "StrideToIterator",
+      "printedName": "StrideToIterator",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_start",
+          "printedName": "_start",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s16StrideToIteratorV6_startxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s16StrideToIteratorV6_startxvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_end",
+          "printedName": "_end",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s16StrideToIteratorV4_endxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s16StrideToIteratorV4_endxvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_stride",
+          "printedName": "_stride",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Stride"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Stride"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s16StrideToIteratorV7_stride0A0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s16StrideToIteratorV7_stride0A0Qzvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 2,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_current",
+          "printedName": "_current",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(index: Optional<Int>, value: τ_0_0)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<Int>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(index: Optional<Int>, value: τ_0_0)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<Int>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Int",
+                          "printedName": "Int",
+                          "usr": "s:Si"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s16StrideToIteratorV8_currentSiSg5index_x5valuetvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s16StrideToIteratorV8_currentSiSg5index_x5valuetvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 3,
+          "hasStorage": true
+        },
+        {
+          "kind": "Function",
+          "name": "next",
+          "printedName": "next()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16StrideToIteratorV4nextxSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s16StrideToIteratorV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "StrideTo",
+      "printedName": "StrideTo",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_start",
+          "printedName": "_start",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s8StrideToV6_startxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s8StrideToV6_startxvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_end",
+          "printedName": "_end",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s8StrideToV4_endxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s8StrideToV4_endxvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_stride",
+          "printedName": "_stride",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Stride"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Stride"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s8StrideToV7_stride0A0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s8StrideToV7_stride0A0Qzvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 2,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Function",
+          "name": "makeIterator",
+          "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "StrideToIterator",
+              "printedName": "StrideToIterator<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s16StrideToIteratorV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s8StrideToV12makeIterators0abD0VyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "underestimatedCount",
+          "printedName": "underestimatedCount",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s8StrideToV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s8StrideToV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "customMirror",
+          "printedName": "customMirror",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Mirror",
+              "printedName": "Mirror",
+              "usr": "s:s6MirrorV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s8StrideToV12customMirrors0D0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s8StrideToV12customMirrors0D0Vvp",
+          "moduleName": "Swift"
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s8StrideToV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "CustomReflectable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "stride",
+      "printedName": "stride(from:to:by:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "StrideTo",
+          "printedName": "StrideTo<τ_0_0>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "usr": "s:s8StrideToV"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "DependentMember",
+          "printedName": "τ_0_0.Stride"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s6stride4from2to2bys8StrideToVyxGx_x0E0QztSxRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "StrideThroughIterator",
+      "printedName": "StrideThroughIterator",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_start",
+          "printedName": "_start",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s21StrideThroughIteratorV6_startxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s21StrideThroughIteratorV6_startxvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_end",
+          "printedName": "_end",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s21StrideThroughIteratorV4_endxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s21StrideThroughIteratorV4_endxvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_stride",
+          "printedName": "_stride",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Stride"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Stride"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s21StrideThroughIteratorV7_stride0A0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s21StrideThroughIteratorV7_stride0A0Qzvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 2,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_current",
+          "printedName": "_current",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(index: Optional<Int>, value: τ_0_0)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<Int>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(index: Optional<Int>, value: τ_0_0)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<Int>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Int",
+                          "printedName": "Int",
+                          "usr": "s:Si"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s21StrideThroughIteratorV8_currentSiSg5index_x5valuetvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s21StrideThroughIteratorV8_currentSiSg5index_x5valuetvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 3,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_didReturnEnd",
+          "printedName": "_didReturnEnd",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s21StrideThroughIteratorV13_didReturnEndSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s21StrideThroughIteratorV13_didReturnEndSbvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "HasInitialValue",
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 4,
+          "hasStorage": true
+        },
+        {
+          "kind": "Function",
+          "name": "next",
+          "printedName": "next()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s21StrideThroughIteratorV4nextxSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s21StrideThroughIteratorV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "StrideThrough",
+      "printedName": "StrideThrough",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_start",
+          "printedName": "_start",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13StrideThroughV6_startxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13StrideThroughV6_startxvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_end",
+          "printedName": "_end",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13StrideThroughV4_endxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13StrideThroughV4_endxvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_stride",
+          "printedName": "_stride",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.Stride"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Stride"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13StrideThroughV7_stride0A0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13StrideThroughV7_stride0A0Qzvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 2,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Function",
+          "name": "makeIterator",
+          "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "StrideThroughIterator",
+              "printedName": "StrideThroughIterator<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s21StrideThroughIteratorV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13StrideThroughV12makeIterators0abD0VyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "underestimatedCount",
+          "printedName": "underestimatedCount",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13StrideThroughV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13StrideThroughV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "customMirror",
+          "printedName": "customMirror",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Mirror",
+              "printedName": "Mirror",
+              "usr": "s:s6MirrorV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13StrideThroughV12customMirrors0D0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Strideable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13StrideThroughV12customMirrors0D0Vvp",
+          "moduleName": "Swift"
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s13StrideThroughV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "CustomReflectable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "stride",
+      "printedName": "stride(from:through:by:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "StrideThrough",
+          "printedName": "StrideThrough<τ_0_0>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "usr": "s:s13StrideThroughV"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "DependentMember",
+          "printedName": "τ_0_0.Stride"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s6stride4from7through2bys13StrideThroughVyxGx_x0E0QztSxRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Strideable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "String",
+      "printedName": "String",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_guts",
+          "printedName": "_guts",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "_StringGuts",
+              "printedName": "_StringGuts",
+              "usr": "s:s11_StringGutsV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_StringGuts",
+                  "printedName": "_StringGuts",
+                  "usr": "s:s11_StringGutsV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS5_gutss11_StringGutsVvg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "_StringGuts",
+                  "printedName": "_StringGuts",
+                  "usr": "s:s11_StringGutsV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS5_gutss11_StringGutsVvs",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS5_gutss11_StringGutsVvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:S2Sycfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSySSSJcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS4fromSSs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
+        },
+        {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:ShsSERzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Encodable, Element : Hashable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -81932,705 +95131,364 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
-          "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:ShsSeRzrlE4fromShyxGs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Decodable, Element : Hashable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "printedName": "init(cString:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Element>",
-              "usr": "s:Sh",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafePointer",
+              "printedName": "UnsafePointer<Int8>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int8",
+                  "printedName": "Int8",
+                  "usr": "s:s4Int8V"
+                }
+              ],
+              "usr": "s:SP"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS7cStringSSSPys4Int8VG_tcfc",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(cString:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafePointer",
+              "printedName": "UnsafePointer<UInt8>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt8",
+                  "printedName": "UInt8",
+                  "usr": "s:s5UInt8V"
+                }
+              ],
+              "usr": "s:SP"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS7cStringSSSPys5UInt8VG_tcfc",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(validatingUTF8:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<String>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafePointer",
+              "printedName": "UnsafePointer<Int8>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int8",
+                  "printedName": "Int8",
+                  "usr": "s:s4Int8V"
+                }
+              ],
+              "usr": "s:SP"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS14validatingUTF8SSSgSPys4Int8VG_tcfc",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "decodeCString",
+          "printedName": "decodeCString(_:as:repairingInvalidCodeUnits:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<(result: String, repairsMade: Bool)>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(result: String, repairsMade: Bool)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "String",
+                      "printedName": "String",
+                      "usr": "s:SS"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<UnsafePointer<τ_0_0.CodeUnit>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafePointer",
+                  "printedName": "UnsafePointer<τ_0_0.CodeUnit>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.CodeUnit"
+                    }
+                  ],
+                  "usr": "s:SP"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_0_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
               ]
             },
             {
               "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
+              "name": "Bool",
+              "printedName": "Bool",
+              "hasDefaultArg": true,
+              "usr": "s:Sb"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS13decodeCString_2as25repairingInvalidCodeUnitsSS6result_Sb11repairsMadetSgSPy0F4UnitQzGSg_xmSbts16_UnicodeEncodingRzlFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _UnicodeEncoding>",
+          "static": true,
+          "declAttributes": [
+            "Specialize",
+            "Specialize"
           ]
         },
         {
           "kind": "Function",
-          "name": "insert",
-          "printedName": "insert(_:)",
-          "declKind": "Func",
-          "usr": "s:Shss11AnyHashableVRszrlE6insertySb8inserted_qd__17memberAfterInserttqd__SHRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, ConcreteElement where Element == AnyHashable, ConcreteElement : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "name": "withCString",
+          "printedName": "withCString(_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(inserted: Bool, memberAfterInsert: ConcreteElement)",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafePointer<Int8>) throws -> τ_0_0",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "ConcreteElement"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "ConcreteElement"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "update",
-          "printedName": "update(with:)",
-          "declKind": "Func",
-          "usr": "s:Shss11AnyHashableVRszrlE6update4withqd__Sgqd___tSHRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, ConcreteElement where Element == AnyHashable, ConcreteElement : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "ConcreteElement?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "ConcreteElement"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "ConcreteElement"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "remove",
-          "printedName": "remove(_:)",
-          "declKind": "Func",
-          "usr": "s:Shss11AnyHashableVRszrlE6removeyqd__Sgqd__SHRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, ConcreteElement where Element == AnyHashable, ConcreteElement : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "ConcreteElement?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "ConcreteElement"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "ConcreteElement"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(minimumCapacity:)",
-          "declKind": "Constructor",
-          "usr": "s:Sh15minimumCapacityShyxGSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(arrayLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Sh12arrayLiteralShyxGxd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "[Set<Element>.Element]",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
+                  "name": "UnsafePointer",
+                  "printedName": "UnsafePointer<Int8>",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
+                      "name": "Int8",
+                      "printedName": "Int8",
+                      "usr": "s:s4Int8V"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS11withCStringyxxSPys4Int8VGKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Var",
+          "name": "customMirror",
+          "printedName": "customMirror",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Mirror",
+              "printedName": "Mirror",
+              "usr": "s:s6MirrorV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS12customMirrors0B0Vvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS12customMirrors0B0Vvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "customPlaygroundQuickLook",
+          "printedName": "customPlaygroundQuickLook",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "_PlaygroundQuickLook",
+              "printedName": "_PlaygroundQuickLook",
+              "usr": "s:s20_PlaygroundQuickLookO"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_PlaygroundQuickLook",
+                  "printedName": "_PlaygroundQuickLook",
+                  "usr": "s:s20_PlaygroundQuickLookO"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
-          "kind": "TypeAlias",
-          "name": "ArrayLiteralElement",
-          "printedName": "ArrayLiteralElement",
-          "declKind": "TypeAlias",
-          "usr": "s:Sh19ArrayLiteralElementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
+          "kind": "Function",
+          "name": "write",
+          "printedName": "write(_:)",
           "children": [
             {
               "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS5writeyySSF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "write",
+          "printedName": "write(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Element"
+              "printedName": "τ_0_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "makeIterator",
-          "printedName": "makeIterator()",
+          ],
           "declKind": "Func",
-          "usr": "s:Sh12makeIterators03SetB0VyxGyF",
-          "location": "",
+          "usr": "s:SS5write2toyxz_ts16TextOutputStreamRzlF",
           "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "SetIterator",
-              "printedName": "SetIterator<Element>",
-              "usr": "s:s11SetIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "contains",
-          "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh8containsySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
+          "genericSig": "<τ_0_0 where τ_0_0 : TextOutputStream>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "Set<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:Sh10startIndexSh0B0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "Set<Element>.Index",
-              "usr": "s:Sh5IndexV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh10startIndexSh0B0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Set<Element>.Index",
-                  "usr": "s:Sh5IndexV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:Sh8endIndexSh0B0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "Set<Element>.Index",
-              "usr": "s:Sh5IndexV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh8endIndexSh0B0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Set<Element>.Index",
-                  "usr": "s:Sh5IndexV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:Sh5index5afterSh5IndexVyx_GAE_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "Set<Element>.Index",
-              "usr": "s:Sh5IndexV"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "Set<Element>.Index",
-              "usr": "s:Sh5IndexV"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "firstIndex",
-          "printedName": "firstIndex(of:)",
-          "declKind": "Func",
-          "usr": "s:Sh10firstIndex2ofSh0B0Vyx_GSgx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Set<Element>.Index?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Set<Element>.Index",
-                  "usr": "s:Sh5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "Set<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "count",
-          "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:Sh5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isEmpty",
-          "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:Sh7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "first",
-          "printedName": "first",
-          "declKind": "Var",
-          "usr": "s:Sh5firstxSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh5firstxSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "Element?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:Sh7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:Sh8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "SetIterator",
-              "printedName": "SetIterator<Element>",
-              "usr": "s:s11SetIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:Sh11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<Set<Element>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Set",
-                  "printedName": "Set<Element>",
-                  "usr": "s:Sh",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:Sh7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DefaultIndices",
-              "printedName": "DefaultIndices<Set<Element>>",
-              "usr": "s:SI",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Set",
-                  "printedName": "Set<Element>",
-                  "usr": "s:Sh",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:Sh4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -82643,16 +95501,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Sh9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -82664,11 +95524,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -82676,29 +95531,909 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(decoding:as:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_0_1.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS8decoding2asSSx_q_mtcSlRzs16_UnicodeEncodingR_8CodeUnitQy_7ElementRtzr0_lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection, τ_0_1 : _UnicodeEncoding, τ_0_0.Element == τ_0_1.CodeUnit>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(decodingCString:as:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafePointer",
+              "printedName": "UnsafePointer<τ_0_0.CodeUnit>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.CodeUnit"
+                }
+              ],
+              "usr": "s:SP"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_0_0.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS15decodingCString2asSSSPy8CodeUnitQzG_xmtcs16_UnicodeEncodingRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _UnicodeEncoding>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
-          "name": "insert",
-          "printedName": "insert(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh6insertySb8inserted_x17memberAfterInserttxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
+          "name": "withCString",
+          "printedName": "withCString(encodedAs:_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(inserted: Bool, memberAfterInsert: Set<Element>.Element)",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_0_1.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ]
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafePointer<τ_0_1.CodeUnit>) throws -> τ_0_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafePointer",
+                  "printedName": "UnsafePointer<τ_0_1.CodeUnit>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_1.CodeUnit"
+                    }
+                  ],
+                  "usr": "s:SP"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS11withCString9encodedAs_xq_m_xSPy8CodeUnitQy_GKXEtKs16_UnicodeEncodingR_r0_lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_1 : _UnicodeEncoding>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Scalar",
+              "printedName": "Unicode.Scalar",
+              "usr": "s:s7UnicodeO6ScalarV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSySSs7UnicodeO6ScalarVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(stringLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS13stringLiteralS2S_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS16debugDescriptionSSvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "append",
+          "printedName": "append(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6appendyySSF",
+          "moduleName": "Swift",
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS1poiyS2S_SStFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Semantics",
+            "Effects",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS2peoiyySSz_SStFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "lowercased",
+          "printedName": "lowercased()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS10lowercasedSSyF",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "uppercased",
+          "printedName": "uppercased()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS10uppercasedSSyF",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSySSxcs25LosslessStringConvertibleRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : LosslessStringConvertible>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "description",
+          "printedName": "description",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS11descriptionSSvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS10startIndexSS0B0Vvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS10startIndexSS0B0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS8endIndexSS0B0Vvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS8endIndexSS0B0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "count",
+          "printedName": "count",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS5countSivg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS5countSivp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS5index5afterSS5IndexVAD_tF",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS5index6beforeSS5IndexVAD_tF",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS5index_8offsetBySS5IndexVAD_SitF",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:limitedBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<String.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS5index_8offsetBy07limitedC0SS5IndexVSgAE_SiAEtF",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(from:to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS8distance4from2toSiSS5IndexV_AEtF",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SSySJSS5IndexVcip",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS2eeoiySbSS_SStFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS1loiySbSS_SStFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "Index",
+          "printedName": "Index",
+          "children": [
+            {
+              "kind": "Var",
+              "name": "_compoundOffset",
+              "printedName": "_compoundOffset",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt64",
+                  "printedName": "UInt64",
+                  "usr": "s:s6UInt64V"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt64",
+                      "printedName": "UInt64",
+                      "usr": "s:s6UInt64V"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS5IndexV15_compoundOffsets6UInt64Vvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS5IndexV15_compoundOffsets6UInt64Vvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_utf8Buffer",
+              "printedName": "_utf8Buffer",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_ValidUTF8Buffer",
+                  "printedName": "_ValidUTF8Buffer<UInt32>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt32",
+                      "printedName": "UInt32",
+                      "usr": "s:s6UInt32V"
+                    }
+                  ],
+                  "usr": "s:s16_ValidUTF8BufferV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_ValidUTF8Buffer",
+                      "printedName": "_ValidUTF8Buffer<UInt32>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UInt32",
+                          "printedName": "UInt32",
+                          "usr": "s:s6UInt32V"
+                        }
+                      ],
+                      "usr": "s:s16_ValidUTF8BufferV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS5IndexV11_utf8Buffers010_ValidUTF8C0Vys6UInt32VGvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS5IndexV11_utf8Buffers010_ValidUTF8C0Vys6UInt32VGvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "HasInitialValue",
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 1,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_graphemeStrideCache",
+              "printedName": "_graphemeStrideCache",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt16",
+                  "printedName": "UInt16",
+                  "usr": "s:s6UInt16V"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt16",
+                      "printedName": "UInt16",
+                      "usr": "s:s6UInt16V"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS5IndexV20_graphemeStrideCaches6UInt16Vvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS5IndexV20_graphemeStrideCaches6UInt16Vvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "HasInitialValue",
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 2,
+              "hasStorage": true
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -82707,179 +96442,1260 @@
                   "usr": "s:Sb"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS5IndexV2eeoiySbAB_ABtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "Set<Element>.Element",
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS5IndexV1loiySbAB_ABtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "hash",
+              "printedName": "hash(into:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Hasher",
+                  "printedName": "Hasher",
+                  "usr": "s:s6HasherV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS5IndexV4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "hashValue",
+              "printedName": "hashValue",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS5IndexV9hashValueSivg",
+                  "moduleName": "Swift",
+                  "implicit": true
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS5IndexV9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
+            },
+            {
+              "kind": "Constructor",
+              "name": "init",
+              "printedName": "init(encodedOffset:transcodedOffset:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV13encodedOffset010transcodedC0ABSi_Sitcfc",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "Inlinable",
+                "Inline"
+              ]
+            },
+            {
+              "kind": "Constructor",
+              "name": "init",
+              "printedName": "init(from:adjustingEncodedOffsetBy:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV4from24adjustingEncodedOffsetByA2B_Sitcfc",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "Inlinable",
+                "Inline"
+              ]
+            },
+            {
+              "kind": "Constructor",
+              "name": "init",
+              "printedName": "init(encodedOffset:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV13encodedOffsetABSi_tcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Constructor",
+              "name": "init",
+              "printedName": "init(encodedOffset:transcodedOffset:buffer:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "_ValidUTF8Buffer",
+                  "printedName": "_ValidUTF8Buffer<UInt32>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt32",
+                      "printedName": "UInt32",
+                      "usr": "s:s6UInt32V"
+                    }
+                  ],
+                  "usr": "s:s16_ValidUTF8BufferV"
+                }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV13encodedOffset010transcodedC06bufferABSi_Sis16_ValidUTF8BufferVys6UInt32VGtcfc",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Constructor",
+              "name": "init",
+              "printedName": "init(encodedOffset:characterStride:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV13encodedOffset15characterStrideABSi_Sitcfc",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "encodedOffset",
+              "printedName": "encodedOffset",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS5IndexV13encodedOffsetSivg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS5IndexV13encodedOffsetSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Constructor",
+              "name": "init",
+              "printedName": "init(_:within:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV_6withinABSgAB_SStcfc",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Function",
+              "name": "samePosition",
+              "printedName": "samePosition(in:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF8View",
+                  "printedName": "String.UTF8View",
+                  "usr": "s:SS8UTF8ViewV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS5IndexV12samePosition2inABSgSS8UTF8ViewV_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "samePosition",
+              "printedName": "samePosition(in:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF16View",
+                  "printedName": "String.UTF16View",
+                  "usr": "s:SS9UTF16ViewV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS5IndexV12samePosition2inABSgSS9UTF16ViewV_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Constructor",
+              "name": "init",
+              "printedName": "init(_:within:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnicodeScalarView",
+                  "printedName": "String.UnicodeScalarView",
+                  "usr": "s:SS17UnicodeScalarViewV"
+                }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV_6withinABSgAB_SS17UnicodeScalarViewVtcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "samePosition",
+              "printedName": "samePosition(in:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS5IndexV12samePosition2inABSgSS_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Constructor",
+              "name": "init",
+              "printedName": "init(_:within:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF16View",
+                  "printedName": "String.UTF16View",
+                  "usr": "s:SS9UTF16ViewV"
+                }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV_6withinABSgAB_SS9UTF16ViewVtcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "samePosition",
+              "printedName": "samePosition(in:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnicodeScalarView",
+                  "printedName": "String.UnicodeScalarView",
+                  "usr": "s:SS17UnicodeScalarViewV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS5IndexV12samePosition2inABSgSS17UnicodeScalarViewV_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Constructor",
+              "name": "init",
+              "printedName": "init(_:within:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF8View",
+                  "printedName": "String.UTF8View",
+                  "usr": "s:SS8UTF8ViewV"
+                }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV_6withinABSgAB_SS8UTF8ViewVtcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SS5IndexV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "Equatable",
+            "Comparable",
+            "Hashable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(stringInterpolation:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<String>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "usr": "s:Sa"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS19stringInterpolationS2Sd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Effects",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(stringInterpolationSegment:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS26stringInterpolationSegmentSSx_tclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(stringInterpolationSegment:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS26stringInterpolationSegmentSSx_tcs20TextOutputStreamableRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : TextOutputStreamable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(stringInterpolationSegment:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS26stringInterpolationSegmentSSx_tcs23CustomStringConvertibleRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CustomStringConvertible>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(stringInterpolationSegment:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS26stringInterpolationSegmentSSx_tcs23CustomStringConvertibleRzs20TextOutputStreamableRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : CustomStringConvertible, τ_0_0 : TextOutputStreamable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(repeating:count:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS9repeating5countS2S_Sitcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isEmpty",
+          "printedName": "isEmpty",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS7isEmptySbvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
-          "name": "update",
-          "printedName": "update(with:)",
-          "declKind": "Func",
-          "usr": "s:Sh6update4withxSgx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
+          "name": "hasPrefix",
+          "printedName": "hasPrefix(_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Set<Element>.Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "Set<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS9hasPrefixySbSSF",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "hasSuffix",
+          "printedName": "hasSuffix(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS9hasSuffixySbSSF",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:radix:uppercase:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "hasDefaultArg": true,
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "hasDefaultArg": true,
+              "usr": "s:Sb"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS_5radix9uppercaseSSx_SiSbtcSzRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : BinaryInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(repeating:count:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS9repeating5countSSSJ_Sitcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSySSxcs25LosslessStringConvertibleRzSTRzSJ7ElementSTRtzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : LosslessStringConvertible, τ_0_0 : Sequence, τ_0_0.Element == Character>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSySSxcSTRzSJ7ElementRtzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element == Character>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
-          "name": "remove",
-          "printedName": "remove(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh6removeyxSgxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
+          "name": "reserveCapacity",
+          "printedName": "reserveCapacity(_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Set<Element>.Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
+              "name": "Void",
+              "printedName": "()"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "Set<Element>.Element",
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS15reserveCapacityyySiF",
+          "moduleName": "Swift",
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "append",
+          "printedName": "append(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6appendyySJF",
+          "moduleName": "Swift",
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "append",
+          "printedName": "append(contentsOf:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6append10contentsOfySS_tF",
+          "moduleName": "Swift",
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "append",
+          "printedName": "append(contentsOf:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6append10contentsOfySs_tF",
+          "moduleName": "Swift",
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "append",
+          "printedName": "append(contentsOf:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6append10contentsOfyx_tSTRzSJ7ElementRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element == Character>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "replaceSubrange",
+          "printedName": "replaceSubrange(_:with:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<String.Index>",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS15replaceSubrange_4withySnySS5IndexVG_xtSlRzSJ7ElementRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element == Character>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "insert",
+          "printedName": "insert(_:at:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6insert_2atySJ_SS5IndexVtF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "insert",
+          "printedName": "insert(contentsOf:at:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6insert10contentsOf2atyx_SS5IndexVtSlRzSJ7ElementRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element == Character>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "remove",
           "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:Sh6remove2atxSh5IndexVyx_G_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "Set<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
             },
             {
               "kind": "TypeNominal",
               "name": "Index",
-              "printedName": "Set<Element>.Index",
-              "usr": "s:Sh5IndexV"
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6remove2atSJSS5IndexV_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "removeSubrange",
+          "printedName": "removeSubrange(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<String.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS14removeSubrangeyySnySS5IndexVGF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeAll",
           "printedName": "removeAll(keepingCapacity:)",
-          "declKind": "Func",
-          "usr": "s:Sh9removeAll15keepingCapacityySb_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -82893,988 +97709,125 @@
               "hasDefaultArg": true,
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS9removeAll15keepingCapacityySb_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
-          "name": "removeFirst",
-          "printedName": "removeFirst()",
-          "declKind": "Func",
-          "usr": "s:Sh11removeFirstxyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "Set<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:S2hyxGycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "name": "max",
+          "printedName": "max(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:ShyShyxGqd__c7ElementQyd__RszSTRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, Source where Element : Hashable, Element == Source.Element, Source : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Source"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isSubset",
-          "printedName": "isSubset(of:)",
-          "declKind": "Func",
-          "usr": "s:Sh8isSubset2ofSbqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "S"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS3maxyxx_xtSLRzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
-          "name": "isStrictSubset",
-          "printedName": "isStrictSubset(of:)",
-          "declKind": "Func",
-          "usr": "s:Sh14isStrictSubset2ofSbqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "name": "min",
+          "printedName": "min(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isSuperset",
-          "printedName": "isSuperset(of:)",
-          "declKind": "Func",
-          "usr": "s:Sh10isSuperset2ofSbqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "S"
+              "printedName": "τ_0_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isStrictSuperset",
-          "printedName": "isStrictSuperset(of:)",
+          ],
           "declKind": "Func",
-          "usr": "s:Sh16isStrictSuperset2ofSbqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
+          "usr": "s:SS3minyxx_xtSLRzlF",
           "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
           "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isDisjoint",
-          "printedName": "isDisjoint(with:)",
-          "declKind": "Func",
-          "usr": "s:Sh10isDisjoint4withSbqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "union",
-          "printedName": "union(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh5unionyShyxGqd__7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formUnion",
-          "printedName": "formUnion(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh9formUnionyyqd__7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "subtracting",
-          "printedName": "subtracting(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh11subtractingyShyxGqd__7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "subtract",
-          "printedName": "subtract(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh8subtractyyqd__7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "intersection",
-          "printedName": "intersection(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh12intersectionyShyxGqd__7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIntersection",
-          "printedName": "formIntersection(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh16formIntersectionyyqd__7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "symmetricDifference",
-          "printedName": "symmetricDifference(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh19symmetricDifferenceyShyxGqd__7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formSymmetricDifference",
-          "printedName": "formSymmetricDifference(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh23formSymmetricDifferenceyyqd__7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "description",
-          "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:Sh11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "debugDescription",
-          "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Sh16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "subtract",
-          "printedName": "subtract(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh8subtractyyShyxGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isSubset",
-          "printedName": "isSubset(of:)",
-          "declKind": "Func",
-          "usr": "s:Sh8isSubset2ofSbShyxG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isSuperset",
-          "printedName": "isSuperset(of:)",
-          "declKind": "Func",
-          "usr": "s:Sh10isSuperset2ofSbShyxG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isDisjoint",
-          "printedName": "isDisjoint(with:)",
-          "declKind": "Func",
-          "usr": "s:Sh10isDisjoint4withSbShyxG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "subtracting",
-          "printedName": "subtracting(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh11subtractingyShyxGABF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isStrictSuperset",
-          "printedName": "isStrictSuperset(of:)",
-          "declKind": "Func",
-          "usr": "s:Sh16isStrictSuperset2ofSbShyxG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isStrictSubset",
-          "printedName": "isStrictSubset(of:)",
-          "declKind": "Func",
-          "usr": "s:Sh14isStrictSubset2ofSbShyxG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "intersection",
-          "printedName": "intersection(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh12intersectionyShyxGABF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formSymmetricDifference",
-          "printedName": "formSymmetricDifference(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh23formSymmetricDifferenceyyShyxGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "Struct",
-          "usr": "s:Sh5IndexV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "conformingProtocols": [
-            "Comparable",
-            "Hashable",
-            "Equatable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
+          "name": "UnicodeScalarView",
+          "printedName": "UnicodeScalarView",
           "children": [
             {
               "kind": "Var",
-              "name": "hashValue",
-              "printedName": "hashValue",
+              "name": "_guts",
+              "printedName": "_guts",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_StringGuts",
+                  "printedName": "_StringGuts",
+                  "usr": "s:s11_StringGutsV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_StringGuts",
+                      "printedName": "_StringGuts",
+                      "usr": "s:s11_StringGutsV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS17UnicodeScalarViewV5_gutss11_StringGutsVvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
               "declKind": "Var",
-              "usr": "s:Sh5IndexV9hashValueSivp",
-              "location": "",
+              "usr": "s:SS17UnicodeScalarViewV5_gutss11_StringGutsVvp",
               "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_coreOffset",
+              "printedName": "_coreOffset",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -83886,11 +97839,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Sh5IndexV9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Element where Element : Hashable>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -83898,22 +97846,634 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS17UnicodeScalarViewV11_coreOffsetSivg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS17UnicodeScalarViewV11_coreOffsetSivp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 1,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "startIndex",
+              "printedName": "startIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS17UnicodeScalarViewV10startIndexSS0E0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS17UnicodeScalarViewV10startIndexSS0E0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "endIndex",
+              "printedName": "endIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS17UnicodeScalarViewV8endIndexSS0E0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS17UnicodeScalarViewV8endIndexSS0E0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
-              "name": "hash",
-              "printedName": "hash(into:)",
+              "name": "index",
+              "printedName": "index(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
               "declKind": "Func",
-              "usr": "s:Sh5IndexV4hash4intoys6HasherVz_tF",
-              "location": "",
+              "usr": "s:SS17UnicodeScalarViewV5index5afterSS5IndexVAF_tF",
               "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
               "declAttributes": [
                 "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(before:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
               ],
+              "declKind": "Func",
+              "usr": "s:SS17UnicodeScalarViewV5index6beforeSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Scalar",
+                  "printedName": "Unicode.Scalar",
+                  "usr": "s:s7UnicodeO6ScalarV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SS17UnicodeScalarViewVys0A0O0B0VSS5IndexVcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "TypeDecl",
+              "name": "Iterator",
+              "printedName": "Iterator",
+              "children": [
+                {
+                  "kind": "Var",
+                  "name": "_guts",
+                  "printedName": "_guts",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_StringGuts",
+                      "printedName": "_StringGuts",
+                      "usr": "s:s11_StringGutsV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "_StringGuts",
+                          "printedName": "_StringGuts",
+                          "usr": "s:s11_StringGutsV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS17UnicodeScalarViewV8IteratorV5_gutss11_StringGutsVvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS17UnicodeScalarViewV8IteratorV5_gutss11_StringGutsVvp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 0,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Var",
+                  "name": "_asciiIterator",
+                  "printedName": "_asciiIterator",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<_UnmanagedString<UInt8>.UnicodeScalarIterator>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UnicodeScalarIterator",
+                          "printedName": "_UnmanagedString<UInt8>.UnicodeScalarIterator",
+                          "usr": "s:s16_UnmanagedStringV21UnicodeScalarIteratorV"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Optional",
+                          "printedName": "Optional<_UnmanagedString<UInt8>.UnicodeScalarIterator>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UnicodeScalarIterator",
+                              "printedName": "_UnmanagedString<UInt8>.UnicodeScalarIterator",
+                              "usr": "s:s16_UnmanagedStringV21UnicodeScalarIteratorV"
+                            }
+                          ],
+                          "usr": "s:Sq"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS17UnicodeScalarViewV8IteratorV06_asciiD0s16_UnmanagedStringV0abD0Vys5UInt8V_GSgvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS17UnicodeScalarViewV8IteratorV06_asciiD0s16_UnmanagedStringV0abD0Vys5UInt8V_GSgvp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "HasInitialValue",
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 1,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Var",
+                  "name": "_utf16Iterator",
+                  "printedName": "_utf16Iterator",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<_UnmanagedString<UInt16>.UnicodeScalarIterator>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UnicodeScalarIterator",
+                          "printedName": "_UnmanagedString<UInt16>.UnicodeScalarIterator",
+                          "usr": "s:s16_UnmanagedStringV21UnicodeScalarIteratorV"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Optional",
+                          "printedName": "Optional<_UnmanagedString<UInt16>.UnicodeScalarIterator>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UnicodeScalarIterator",
+                              "printedName": "_UnmanagedString<UInt16>.UnicodeScalarIterator",
+                              "usr": "s:s16_UnmanagedStringV21UnicodeScalarIteratorV"
+                            }
+                          ],
+                          "usr": "s:Sq"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS17UnicodeScalarViewV8IteratorV06_utf16D0s16_UnmanagedStringV0abD0Vys6UInt16V_GSgvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS17UnicodeScalarViewV8IteratorV06_utf16D0s16_UnmanagedStringV0abD0Vys6UInt16V_GSgvp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "HasInitialValue",
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 2,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Var",
+                  "name": "_opaqueIterator",
+                  "printedName": "_opaqueIterator",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<_UnmanagedOpaqueString.UnicodeScalarIterator>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UnicodeScalarIterator",
+                          "printedName": "_UnmanagedOpaqueString.UnicodeScalarIterator",
+                          "usr": "s:s22_UnmanagedOpaqueStringV21UnicodeScalarIteratorV"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Optional",
+                          "printedName": "Optional<_UnmanagedOpaqueString.UnicodeScalarIterator>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UnicodeScalarIterator",
+                              "printedName": "_UnmanagedOpaqueString.UnicodeScalarIterator",
+                              "usr": "s:s22_UnmanagedOpaqueStringV21UnicodeScalarIteratorV"
+                            }
+                          ],
+                          "usr": "s:Sq"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS17UnicodeScalarViewV8IteratorV07_opaqueD0s22_UnmanagedOpaqueStringV0abD0VSgvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS17UnicodeScalarViewV8IteratorV07_opaqueD0s22_UnmanagedOpaqueStringV0abD0VSgvp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "HasInitialValue",
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 3,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Var",
+                  "name": "_smallIterator",
+                  "printedName": "_smallIterator",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<_SmallUTF8String.UnicodeScalarIterator>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UnicodeScalarIterator",
+                          "printedName": "_SmallUTF8String.UnicodeScalarIterator",
+                          "usr": "s:s16_SmallUTF8StringV21UnicodeScalarIteratorV"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Optional",
+                          "printedName": "Optional<_SmallUTF8String.UnicodeScalarIterator>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UnicodeScalarIterator",
+                              "printedName": "_SmallUTF8String.UnicodeScalarIterator",
+                              "usr": "s:s16_SmallUTF8StringV21UnicodeScalarIteratorV"
+                            }
+                          ],
+                          "usr": "s:Sq"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS17UnicodeScalarViewV8IteratorV06_smallD0s16_SmallUTF8StringV0abD0VSgvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS17UnicodeScalarViewV8IteratorV06_smallD0s16_SmallUTF8StringV0abD0VSgvp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "HasInitialValue",
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 4,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Constructor",
+                  "name": "init",
+                  "printedName": "init(_:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Iterator",
+                      "printedName": "String.UnicodeScalarView.Iterator",
+                      "usr": "s:SS17UnicodeScalarViewV8IteratorV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_StringGuts",
+                      "printedName": "_StringGuts",
+                      "usr": "s:s11_StringGutsV"
+                    }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:SS17UnicodeScalarViewV8IteratorVyADs11_StringGutsVcfc",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "next",
+                  "printedName": "next()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<Unicode.Scalar>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Scalar",
+                          "printedName": "Unicode.Scalar",
+                          "usr": "s:s7UnicodeO6ScalarV"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS17UnicodeScalarViewV8IteratorV4nexts0A0O0B0VSgyF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ],
+                  "mutating": true
+                }
+              ],
+              "declKind": "Struct",
+              "usr": "s:SS17UnicodeScalarViewV8IteratorV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "IteratorProtocol"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "makeIterator",
+              "printedName": "makeIterator()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Iterator",
+                  "printedName": "String.UnicodeScalarView.Iterator",
+                  "usr": "s:SS17UnicodeScalarViewV8IteratorV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS17UnicodeScalarViewV12makeIteratorAB0E0VyF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "description",
+              "printedName": "description",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "String",
+                      "printedName": "String",
+                      "usr": "s:SS"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS17UnicodeScalarViewV11descriptionSSvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS17UnicodeScalarViewV11descriptionSSvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "debugDescription",
+              "printedName": "debugDescription",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "String",
+                      "printedName": "String",
+                      "usr": "s:SS"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS17UnicodeScalarViewV16debugDescriptionSSvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS17UnicodeScalarViewV16debugDescriptionSSvp",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Constructor",
+              "name": "init",
+              "printedName": "init()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnicodeScalarView",
+                  "printedName": "String.UnicodeScalarView",
+                  "usr": "s:SS17UnicodeScalarViewV"
+                }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS17UnicodeScalarViewVABycfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "reserveCapacity",
+              "printedName": "reserveCapacity(_:)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -83922,2496 +98482,2164 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Hasher",
-                  "printedName": "Hasher",
-                  "usr": "s:s6HasherV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Sh12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "popFirst",
-          "printedName": "popFirst()",
-          "declKind": "Func",
-          "usr": "s:Sh8popFirstxSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Set<Element>.Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "capacity",
-          "printedName": "capacity",
-          "declKind": "Var",
-          "usr": "s:Sh8capacitySivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh8capacitySivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
                   "name": "Int",
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "reserveCapacity",
-          "printedName": "reserveCapacity(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh15reserveCapacityyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "filter",
-          "printedName": "filter(_:obsoletedInSwift4:)",
-          "declKind": "Func",
-          "usr": "s:Sh6filter_17obsoletedInSwift4SayxGSbxKXE_yttKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "[Set<Element>.Element]",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Set<Element>.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
               ],
+              "declKind": "Func",
+              "usr": "s:SS17UnicodeScalarViewV15reserveCapacityyySiF",
+              "moduleName": "Swift",
+              "mutating": true
+            },
+            {
+              "kind": "Function",
+              "name": "append",
+              "printedName": "append(_:)",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
+                  "name": "Void",
+                  "printedName": "()"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Set<Element>.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "Set<Element>.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_0"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()",
-              "hasDefaultArg": true
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "SetIndex",
-      "printedName": "SetIndex",
-      "declKind": "TypeAlias",
-      "usr": "s:s8SetIndexa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element where Element : Hashable>",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Index",
-          "printedName": "Set<Element>.Index",
-          "usr": "s:Sh5IndexV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "SetIterator",
-      "printedName": "SetIterator",
-      "declKind": "Struct",
-      "usr": "s:s11SetIteratorV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element where Element : Hashable>",
-      "conformingProtocols": [
-        "IteratorProtocol",
-        "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Function",
-          "name": "next",
-          "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s11SetIteratorV4nextxSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s11SetIteratorV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s11SetIteratorV12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11SetIteratorV12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "SetAlgebra",
-      "printedName": "SetAlgebra",
-      "declKind": "Protocol",
-      "usr": "s:s10SetAlgebraP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Equatable, Self : ExpressibleByArrayLiteral>",
-      "conformingProtocols": [
-        "Equatable",
-        "ExpressibleByArrayLiteral"
-      ],
-      "children": [
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s10SetAlgebraPxycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "contains",
-          "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP8containsySb7ElementQzF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Element"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "union",
-          "printedName": "union(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP5unionyxxnF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DynamicSelf",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "intersection",
-          "printedName": "intersection(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP12intersectionyxxnF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DynamicSelf",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "symmetricDifference",
-          "printedName": "symmetricDifference(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP19symmetricDifferenceyxxnF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DynamicSelf",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "insert",
-          "printedName": "insert(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP6insertySb8inserted_7ElementQz17memberAfterInserttAFnF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(inserted: Bool, memberAfterInsert: Self.Element)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Element"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "remove",
-          "printedName": "remove(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP6removey7ElementQzSgAEF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Element"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "update",
-          "printedName": "update(with:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP6update4with7ElementQzSgAFn_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Element"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formUnion",
-          "printedName": "formUnion(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP9formUnionyyxnF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIntersection",
-          "printedName": "formIntersection(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP16formIntersectionyyxnF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formSymmetricDifference",
-          "printedName": "formSymmetricDifference(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP23formSymmetricDifferenceyyxnF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "subtracting",
-          "printedName": "subtracting(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP11subtractingyxxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DynamicSelf",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isSubset",
-          "printedName": "isSubset(of:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP8isSubset2ofSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isDisjoint",
-          "printedName": "isDisjoint(with:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP10isDisjoint4withSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isSuperset",
-          "printedName": "isSuperset(of:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP10isSuperset2ofSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isEmpty",
-          "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:s10SetAlgebraP7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10SetAlgebraP7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : SetAlgebra>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s10SetAlgebraPyxqd__ncSTRd__7ElementQyd__ACRtzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, S where Self : SetAlgebra, S : Sequence, Self.Element == S.Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "subtract",
-          "printedName": "subtract(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP8subtractyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s10SetAlgebraPsEyxqd__cSTRd__7ElementQyd__ACRtzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, S where Self : SetAlgebra, S : Sequence, Self.Element == S.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "subtract",
-          "printedName": "subtract(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraPsE8subtractyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isSubset",
-          "printedName": "isSubset(of:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraPsE8isSubset2ofSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isSuperset",
-          "printedName": "isSuperset(of:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraPsE10isSuperset2ofSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isDisjoint",
-          "printedName": "isDisjoint(with:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraPsE10isDisjoint4withSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "subtracting",
-          "printedName": "subtracting(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraPsE11subtractingyxxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isEmpty",
-          "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:s10SetAlgebraPsE7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10SetAlgebraPsE7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : SetAlgebra>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isStrictSuperset",
-          "printedName": "isStrictSuperset(of:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraPsE16isStrictSuperset2ofSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isStrictSubset",
-          "printedName": "isStrictSubset(of:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraPsE14isStrictSubset2ofSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(arrayLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s10SetAlgebraPs7ElementQz012ArrayLiteralC0RtzrlE05arrayE0xAFd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra, Self.ArrayLiteralElement == Self.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "[Self.Element]",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Element"
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "Slice",
-      "printedName": "Slice",
-      "declKind": "Struct",
-      "usr": "s:s5SliceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Collection>",
-      "conformingProtocols": [
-        "LazySequenceProtocol",
-        "LazyCollectionProtocol",
-        "Collection",
-        "Sequence",
-        "BidirectionalCollection",
-        "MutableCollection",
-        "RandomAccessCollection",
-        "RangeReplaceableCollection"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(base:bounds:)",
-          "declKind": "Constructor",
-          "usr": "s:s5SliceV4base6boundsAByxGx_Sny5IndexQzGtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<Base>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Base"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Base.Index>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "base",
-          "printedName": "base",
-          "declKind": "Var",
-          "usr": "s:s5SliceV4basexvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Base"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5SliceV4basexvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Elements",
-          "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s5SliceVss22LazyCollectionProtocolRzrlE8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : LazyCollectionProtocol>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<Base>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s5SliceV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Index"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s5SliceV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Indices"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s5SliceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s5SliceV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<Base>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s5SliceV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "IndexingIterator",
-              "printedName": "IndexingIterator<Slice<Base>>",
-              "usr": "s:s16IndexingIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Slice",
-                  "printedName": "Slice<Base>",
-                  "usr": "s:s5SliceV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Base"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s5SliceV10startIndex0C0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Index"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5SliceV10startIndex0C0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s5SliceV8endIndex0C0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Index"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5SliceV8endIndex0C0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "indices",
-          "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:s5SliceV7indices7IndicesQzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Indices"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5SliceV7indices7IndicesQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Base.Indices"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceV5index5after5IndexQzAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceV9formIndex5aftery0C0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceV5index_8offsetBy5IndexQzAF_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceV5index_8offsetBy07limitedD05IndexQzSgAG_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Slice<Base>.Index?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Slice<Base>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "τ_0_0.Index"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceV8distance4from2toSi5IndexQz_AGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSKRzrlE5index6before5IndexQzAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSKRzrlE9formIndex6beforey0C0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s5SliceVsSmRzrlEAByxGycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : RangeReplaceableCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<Base>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(repeating:count:)",
-          "declKind": "Constructor",
-          "usr": "s:s5SliceVsSmRzrlE9repeating5countAByxG7ElementQz_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : RangeReplaceableCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<Base>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s5SliceVsSmRzrlEyAByxGqd__cSTRd__7ElementQyd__ADRtzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, S where Base : RangeReplaceableCollection, S : Sequence, Base.Element == S.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<Base>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Base"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "replaceSubrange",
-          "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSmRzrlE15replaceSubrange_4withySny5IndexQzG_qd__tSlRd__7ElementQyd__AHRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, C where Base : RangeReplaceableCollection, C : Collection, Base.Element == C.Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Slice<Base>.Index>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Slice<Base>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "τ_0_0.Index"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "C"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "insert",
-          "printedName": "insert(_:at:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSmRzrlE6insert_2aty7ElementQz_5IndexQztF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "insert",
-          "printedName": "insert(contentsOf:at:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSmRzrlE6insert10contentsOf2atyqd___5IndexQztSlRd__7ElementQyd__AHRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, S where Base : RangeReplaceableCollection, S : Collection, Base.Element == S.Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "remove",
-          "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSmRzrlE6remove2at7ElementQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "removeSubrange",
-          "printedName": "removeSubrange(_:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSmRzrlE14removeSubrangeyySny5IndexQzGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Slice<Base>.Index>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Slice<Base>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "τ_0_0.Index"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "replaceSubrange",
-          "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSKRzSmRzrlE15replaceSubrange_4withySny5IndexSlQzG_qd__tSlRd__7ElementQyd__AHSTRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, C where Base : BidirectionalCollection, Base : RangeReplaceableCollection, C : Collection, Base.Element == C.Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Slice<Base>.Index>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Slice<Base>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "τ_0_0.Index"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "C"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "insert",
-          "printedName": "insert(_:at:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSKRzSmRzrlE6insert_2aty7ElementSTQz_5IndexSlQztF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection, Base : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "insert",
-          "printedName": "insert(contentsOf:at:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSKRzSmRzrlE6insert10contentsOf2atyqd___5IndexSlQztSlRd__7ElementQyd__AHSTRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, S where Base : BidirectionalCollection, Base : RangeReplaceableCollection, S : Collection, Base.Element == S.Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "remove",
-          "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSKRzSmRzrlE6remove2at7ElementSTQz5IndexSlQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection, Base : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Base.Element"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Slice<Base>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "removeSubrange",
-          "printedName": "removeSubrange(_:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSKRzSmRzrlE14removeSubrangeyySny5IndexSlQzGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection, Base : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Slice<Base>.Index>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Slice<Base>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "τ_0_0.Index"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "StaticString",
-      "printedName": "StaticString",
-      "declKind": "Struct",
-      "usr": "s:s12StaticStringV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "CustomReflectable",
-        "_ExpressibleByBuiltinExtendedGraphemeClusterLiteral",
-        "_ExpressibleByBuiltinStringLiteral",
-        "ExpressibleByUnicodeScalarLiteral",
-        "ExpressibleByExtendedGraphemeClusterLiteral",
-        "ExpressibleByStringLiteral",
-        "CustomStringConvertible",
-        "CustomDebugStringConvertible",
-        "_ExpressibleByBuiltinUnicodeScalarLiteral"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Var",
-          "name": "utf8Start",
-          "printedName": "utf8Start",
-          "declKind": "Var",
-          "usr": "s:s12StaticStringV9utf8StartSPys5UInt8VGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafePointer",
-              "printedName": "UnsafePointer<UInt8>",
-              "usr": "s:SP",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt8",
-                  "printedName": "UInt8",
-                  "usr": "s:s5UInt8V"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12StaticStringV9utf8StartSPys5UInt8VGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafePointer",
-                  "printedName": "UnsafePointer<UInt8>",
-                  "usr": "s:SP",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt8",
-                      "printedName": "UInt8",
-                      "usr": "s:s5UInt8V"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "unicodeScalar",
-          "printedName": "unicodeScalar",
-          "declKind": "Var",
-          "usr": "s:s12StaticStringV13unicodeScalars7UnicodeO0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Scalar",
-              "printedName": "Unicode.Scalar",
-              "usr": "s:s7UnicodeO6ScalarV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12StaticStringV13unicodeScalars7UnicodeO0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
                   "name": "Scalar",
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS17UnicodeScalarViewV6appendyys0A0O0B0VF",
+              "moduleName": "Swift",
+              "mutating": true
+            },
+            {
+              "kind": "Function",
+              "name": "append",
+              "printedName": "append(contentsOf:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS17UnicodeScalarViewV6append10contentsOfyx_tSTRzs0A0O0B0V7ElementRtzlF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element == Unicode.Scalar>",
+              "mutating": true
+            },
+            {
+              "kind": "Function",
+              "name": "replaceSubrange",
+              "printedName": "replaceSubrange(_:with:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS17UnicodeScalarViewV15replaceSubrange_4withySnySS5IndexVG_xtSlRzs0A0O0B0V7ElementRtzlF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element == Unicode.Scalar>",
+              "mutating": true
+            },
+            {
+              "kind": "Var",
+              "name": "customMirror",
+              "printedName": "customMirror",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Mirror",
+                      "printedName": "Mirror",
+                      "usr": "s:s6MirrorV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS17UnicodeScalarViewV12customMirrors0E0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS17UnicodeScalarViewV12customMirrors0E0Vvp",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnicodeScalarView",
+                  "printedName": "Substring.UnicodeScalarView",
+                  "usr": "s:Ss17UnicodeScalarViewV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SS17UnicodeScalarViewVySsAAVSnySS5IndexVGcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Available",
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "customPlaygroundQuickLook",
+              "printedName": "customPlaygroundQuickLook",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_PlaygroundQuickLook",
+                  "printedName": "_PlaygroundQuickLook",
+                  "usr": "s:s20_PlaygroundQuickLookO"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_PlaygroundQuickLook",
+                      "printedName": "_PlaygroundQuickLook",
+                      "usr": "s:s20_PlaygroundQuickLookO"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS17UnicodeScalarViewV25customPlaygroundQuickLooks01_efG0Ovg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS17UnicodeScalarViewV25customPlaygroundQuickLooks01_efG0Ovp",
+              "moduleName": "Swift",
+              "deprecated": true,
+              "declAttributes": [
+                "Available"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SS17UnicodeScalarViewV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "BidirectionalCollection",
+            "CustomStringConvertible",
+            "CustomDebugStringConvertible",
+            "Collection",
+            "Sequence",
+            "_SwiftStringView",
+            "RangeReplaceableCollection",
+            "CustomReflectable",
+            "_CustomPlaygroundQuickLookable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnicodeScalarView",
+              "printedName": "String.UnicodeScalarView",
+              "usr": "s:SS17UnicodeScalarViewV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSyS2S17UnicodeScalarViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
-          "name": "utf8CodeUnitCount",
-          "printedName": "utf8CodeUnitCount",
-          "declKind": "Var",
-          "usr": "s:s12StaticStringV17utf8CodeUnitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
+          "name": "unicodeScalars",
+          "printedName": "unicodeScalars",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "UnicodeScalarView",
+              "printedName": "String.UnicodeScalarView",
+              "usr": "s:SS17UnicodeScalarViewV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12StaticStringV17utf8CodeUnitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
+                  "name": "UnicodeScalarView",
+                  "printedName": "String.UnicodeScalarView",
+                  "usr": "s:SS17UnicodeScalarViewV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS14unicodeScalarsSS17UnicodeScalarViewVvg",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnicodeScalarView",
+                  "printedName": "String.UnicodeScalarView",
+                  "usr": "s:SS17UnicodeScalarViewV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS14unicodeScalarsSS17UnicodeScalarViewVvs",
+              "moduleName": "Swift",
+              "mutating": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS14unicodeScalarsSS17UnicodeScalarViewVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "UTF16View",
+          "printedName": "UTF16View",
+          "children": [
+            {
+              "kind": "Var",
+              "name": "startIndex",
+              "printedName": "startIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS9UTF16ViewV10startIndexSS0D0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS9UTF16ViewV10startIndexSS0D0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "endIndex",
+              "printedName": "endIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS9UTF16ViewV8endIndexSS0D0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS9UTF16ViewV8endIndexSS0D0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "TypeDecl",
+              "name": "Indices",
+              "printedName": "Indices",
+              "children": [
+                {
+                  "kind": "Var",
+                  "name": "_elements",
+                  "printedName": "_elements",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UTF16View",
+                      "printedName": "String.UTF16View",
+                      "usr": "s:SS9UTF16ViewV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UTF16View",
+                          "printedName": "String.UTF16View",
+                          "usr": "s:SS9UTF16ViewV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS9UTF16ViewV7IndicesV9_elementsABvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS9UTF16ViewV7IndicesV9_elementsABvp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 0,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Var",
+                  "name": "_startIndex",
+                  "printedName": "_startIndex",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS9UTF16ViewV7IndicesV11_startIndexSS0E0Vvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS9UTF16ViewV7IndicesV11_startIndexSS0E0Vvp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 1,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Var",
+                  "name": "_endIndex",
+                  "printedName": "_endIndex",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS9UTF16ViewV7IndicesV9_endIndexSS0E0Vvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS9UTF16ViewV7IndicesV9_endIndexSS0E0Vvp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 2,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Var",
+                  "name": "startIndex",
+                  "printedName": "startIndex",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS9UTF16ViewV7IndicesV10startIndexSS0E0Vvg",
+                      "moduleName": "Swift"
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS9UTF16ViewV7IndicesV10startIndexSS0E0Vvp",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Var",
+                  "name": "endIndex",
+                  "printedName": "endIndex",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS9UTF16ViewV7IndicesV8endIndexSS0E0Vvg",
+                      "moduleName": "Swift"
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS9UTF16ViewV7IndicesV8endIndexSS0E0Vvp",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Var",
+                  "name": "indices",
+                  "printedName": "indices",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Indices",
+                      "printedName": "String.UTF16View.Indices",
+                      "usr": "s:SS9UTF16ViewV7IndicesV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Indices",
+                          "printedName": "String.UTF16View.Indices",
+                          "usr": "s:SS9UTF16ViewV7IndicesV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS9UTF16ViewV7IndicesV7indicesADvg",
+                      "moduleName": "Swift"
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS9UTF16ViewV7IndicesV7indicesADvp",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Subscript",
+                  "name": "subscript",
+                  "printedName": "subscript(_:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Subscript",
+                  "usr": "s:SS9UTF16ViewV7IndicesVySS5IndexVAFcip",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Subscript",
+                  "name": "subscript",
+                  "printedName": "subscript(_:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Indices",
+                      "printedName": "String.UTF16View.Indices",
+                      "usr": "s:SS9UTF16ViewV7IndicesV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Range",
+                      "printedName": "Range<String.Index>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
+                      ],
+                      "usr": "s:Sn"
+                    }
+                  ],
+                  "declKind": "Subscript",
+                  "usr": "s:SS9UTF16ViewV7IndicesVyADSnySS5IndexVGcip",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "index",
+                  "printedName": "index(after:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS9UTF16ViewV7IndicesV5index5afterSS5IndexVAH_tF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "formIndex",
+                  "printedName": "formIndex(after:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Void",
+                      "printedName": "()"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS9UTF16ViewV7IndicesV9formIndex5afterySS0E0Vz_tF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "index",
+                  "printedName": "index(before:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS9UTF16ViewV7IndicesV5index6beforeSS5IndexVAH_tF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "formIndex",
+                  "printedName": "formIndex(before:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Void",
+                      "printedName": "()"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS9UTF16ViewV7IndicesV9formIndex6beforeySS0E0Vz_tF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "index",
+                  "printedName": "index(_:offsetBy:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS9UTF16ViewV7IndicesV5index_8offsetBySS5IndexVAH_SitF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "index",
+                  "printedName": "index(_:offsetBy:limitedBy:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<String.Index>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS9UTF16ViewV7IndicesV5index_8offsetBy07limitedF0SS5IndexVSgAI_SiAItF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "distance",
+                  "printedName": "distance(from:to:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS9UTF16ViewV7IndicesV8distance4from2toSiSS5IndexV_AItF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                }
+              ],
+              "declKind": "Struct",
+              "usr": "s:SS9UTF16ViewV7IndicesV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "BidirectionalCollection",
+                "Collection",
+                "Sequence"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "indices",
+              "printedName": "indices",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Indices",
+                  "printedName": "String.UTF16View.Indices",
+                  "usr": "s:SS9UTF16ViewV7IndicesV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Indices",
+                      "printedName": "String.UTF16View.Indices",
+                      "usr": "s:SS9UTF16ViewV7IndicesV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS9UTF16ViewV7indicesAB7IndicesVvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS9UTF16ViewV7indicesAB7IndicesVvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS9UTF16ViewV5index5afterSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(before:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS9UTF16ViewV5index6beforeSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(_:offsetBy:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
                   "name": "Int",
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "hasPointerRepresentation",
-          "printedName": "hasPointerRepresentation",
-          "declKind": "Var",
-          "usr": "s:s12StaticStringV24hasPointerRepresentationSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12StaticStringV24hasPointerRepresentationSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isASCII",
-          "printedName": "isASCII",
-          "declKind": "Var",
-          "usr": "s:s12StaticStringV7isASCIISbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12StaticStringV7isASCIISbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUTF8Buffer",
-          "printedName": "withUTF8Buffer(_:)",
-          "declKind": "Func",
-          "usr": "s:s12StaticStringV14withUTF8BufferyxxSRys5UInt8VGXElF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<R>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafeBufferPointer<UInt8>) -> R",
-              "typeAttributes": [
-                "noescape"
               ],
+              "declKind": "Func",
+              "usr": "s:SS9UTF16ViewV5index_8offsetBySS5IndexVAF_SitF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(_:offsetBy:limitedBy:)",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeBufferPointer<UInt8>)",
-                  "usr": "s:SR",
+                  "name": "Optional",
+                  "printedName": "Optional<String.Index>",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "UnsafeBufferPointer",
-                      "printedName": "UnsafeBufferPointer<UInt8>",
-                      "usr": "s:SR",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS9UTF16ViewV5index_8offsetBy07limitedE0SS5IndexVSgAG_SiAGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "distance",
+              "printedName": "distance(from:to:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS9UTF16ViewV8distance4from2toSiSS5IndexV_AGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt16",
+                  "printedName": "UInt16",
+                  "usr": "s:s6UInt16V"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SS9UTF16ViewVys6UInt16VSS5IndexVcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "description",
+              "printedName": "description",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "String",
+                      "printedName": "String",
+                      "usr": "s:SS"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS9UTF16ViewV11descriptionSSvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS9UTF16ViewV11descriptionSSvp",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Var",
+              "name": "debugDescription",
+              "printedName": "debugDescription",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "String",
+                      "printedName": "String",
+                      "usr": "s:SS"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS9UTF16ViewV16debugDescriptionSSvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS9UTF16ViewV16debugDescriptionSSvp",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Var",
+              "name": "_offset",
+              "printedName": "_offset",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS9UTF16ViewV7_offsetSivg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS9UTF16ViewV7_offsetSivp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_length",
+              "printedName": "_length",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS9UTF16ViewV7_lengthSivg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS9UTF16ViewV7_lengthSivp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 1,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_guts",
+              "printedName": "_guts",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_StringGuts",
+                  "printedName": "_StringGuts",
+                  "usr": "s:s11_StringGutsV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_StringGuts",
+                      "printedName": "_StringGuts",
+                      "usr": "s:s11_StringGutsV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS9UTF16ViewV5_gutss11_StringGutsVvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS9UTF16ViewV5_gutss11_StringGutsVvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 2,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "customMirror",
+              "printedName": "customMirror",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Mirror",
+                      "printedName": "Mirror",
+                      "usr": "s:s6MirrorV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS9UTF16ViewV12customMirrors0D0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS9UTF16ViewV12customMirrors0D0Vvp",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF16View",
+                  "printedName": "Substring.UTF16View",
+                  "usr": "s:Ss9UTF16ViewV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SS9UTF16ViewVySsAAVSnySS5IndexVGcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Available",
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "customPlaygroundQuickLook",
+              "printedName": "customPlaygroundQuickLook",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_PlaygroundQuickLook",
+                  "printedName": "_PlaygroundQuickLook",
+                  "usr": "s:s20_PlaygroundQuickLookO"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_PlaygroundQuickLook",
+                      "printedName": "_PlaygroundQuickLook",
+                      "usr": "s:s20_PlaygroundQuickLookO"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS9UTF16ViewV25customPlaygroundQuickLooks01_deF0Ovg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS9UTF16ViewV25customPlaygroundQuickLooks01_deF0Ovp",
+              "moduleName": "Swift",
+              "deprecated": true,
+              "declAttributes": [
+                "Available"
+              ]
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SS9UTF16ViewV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "BidirectionalCollection",
+            "CustomStringConvertible",
+            "CustomDebugStringConvertible",
+            "Collection",
+            "Sequence",
+            "_SwiftStringView",
+            "CustomReflectable",
+            "_CustomPlaygroundQuickLookable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "utf16",
+          "printedName": "utf16",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UTF16View",
+              "printedName": "String.UTF16View",
+              "usr": "s:SS9UTF16ViewV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF16View",
+                  "printedName": "String.UTF16View",
+                  "usr": "s:SS9UTF16ViewV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS5utf16SS9UTF16ViewVvg",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF16View",
+                  "printedName": "String.UTF16View",
+                  "usr": "s:SS9UTF16ViewV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS5utf16SS9UTF16ViewVvs",
+              "moduleName": "Swift",
+              "mutating": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS5utf16SS9UTF16ViewVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UTF16View",
+              "printedName": "String.UTF16View",
+              "usr": "s:SS9UTF16ViewV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSyS2S9UTF16ViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Available",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "UTF8View",
+          "printedName": "UTF8View",
+          "children": [
+            {
+              "kind": "Var",
+              "name": "_guts",
+              "printedName": "_guts",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_StringGuts",
+                  "printedName": "_StringGuts",
+                  "usr": "s:s11_StringGutsV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_StringGuts",
+                      "printedName": "_StringGuts",
+                      "usr": "s:s11_StringGutsV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS8UTF8ViewV5_gutss11_StringGutsVvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS8UTF8ViewV5_gutss11_StringGutsVvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_legacyOffsets",
+              "printedName": "_legacyOffsets",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(start: Int8, end: Int8)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int8",
+                      "printedName": "Int8",
+                      "usr": "s:s4Int8V"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int8",
+                      "printedName": "Int8",
+                      "usr": "s:s4Int8V"
+                    }
+                  ]
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Tuple",
+                      "printedName": "(start: Int8, end: Int8)",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Int8",
+                          "printedName": "Int8",
+                          "usr": "s:s4Int8V"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Int8",
+                          "printedName": "Int8",
+                          "usr": "s:s4Int8V"
+                        }
+                      ]
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS8UTF8ViewV14_legacyOffsetss4Int8V5start_AE3endtvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS8UTF8ViewV14_legacyOffsetss4Int8V5start_AE3endtvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 1,
+              "isLet": true,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_legacyPartialCharacters",
+              "printedName": "_legacyPartialCharacters",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(start: Bool, end: Bool)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    }
+                  ]
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Tuple",
+                      "printedName": "(start: Bool, end: Bool)",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Bool",
+                          "printedName": "Bool",
+                          "usr": "s:Sb"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Bool",
+                          "printedName": "Bool",
+                          "usr": "s:Sb"
+                        }
+                      ]
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS8UTF8ViewV24_legacyPartialCharactersSb5start_Sb3endtvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS8UTF8ViewV24_legacyPartialCharactersSb5start_Sb3endtvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 2,
+              "isLet": true,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "startIndex",
+              "printedName": "startIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS8UTF8ViewV10startIndexSS0D0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS8UTF8ViewV10startIndexSS0D0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "endIndex",
+              "printedName": "endIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS8UTF8ViewV8endIndexSS0D0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS8UTF8ViewV8endIndexSS0D0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS8UTF8ViewV5index5afterSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(before:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS8UTF8ViewV5index6beforeSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "distance",
+              "printedName": "distance(from:to:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS8UTF8ViewV8distance4from2toSiSS5IndexV_AGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt8",
+                  "printedName": "UInt8",
+                  "usr": "s:s5UInt8V"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SS8UTF8ViewVys5UInt8VSS5IndexVcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "description",
+              "printedName": "description",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "String",
+                      "printedName": "String",
+                      "usr": "s:SS"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS8UTF8ViewV11descriptionSSvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS8UTF8ViewV11descriptionSSvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "debugDescription",
+              "printedName": "debugDescription",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "String",
+                      "printedName": "String",
+                      "usr": "s:SS"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS8UTF8ViewV16debugDescriptionSSvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS8UTF8ViewV16debugDescriptionSSvp",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "TypeDecl",
+              "name": "Iterator",
+              "printedName": "Iterator",
+              "children": [
+                {
+                  "kind": "Var",
+                  "name": "_guts",
+                  "printedName": "_guts",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_StringGuts",
+                      "printedName": "_StringGuts",
+                      "usr": "s:s11_StringGutsV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "_StringGuts",
+                          "printedName": "_StringGuts",
+                          "usr": "s:s11_StringGutsV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS8UTF8ViewV8IteratorV5_gutss11_StringGutsVvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS8UTF8ViewV8IteratorV5_gutss11_StringGutsVvp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 0,
+                  "isLet": true,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Var",
+                  "name": "_endOffset",
+                  "printedName": "_endOffset",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Int",
+                          "printedName": "Int",
+                          "usr": "s:Si"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS8UTF8ViewV8IteratorV10_endOffsetSivg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS8UTF8ViewV8IteratorV10_endOffsetSivp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 1,
+                  "isLet": true,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Var",
+                  "name": "_nextOffset",
+                  "printedName": "_nextOffset",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Int",
+                          "printedName": "Int",
+                          "usr": "s:Si"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS8UTF8ViewV8IteratorV11_nextOffsetSivg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS8UTF8ViewV8IteratorV11_nextOffsetSivp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 2,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Var",
+                  "name": "_buffer",
+                  "printedName": "_buffer",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_ValidUTF8Buffer",
+                      "printedName": "_ValidUTF8Buffer<UInt64>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UInt64",
+                          "printedName": "UInt64",
+                          "usr": "s:s6UInt64V"
+                        }
+                      ],
+                      "usr": "s:s16_ValidUTF8BufferV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "_ValidUTF8Buffer",
+                          "printedName": "_ValidUTF8Buffer<UInt64>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt64",
+                              "printedName": "UInt64",
+                              "usr": "s:s6UInt64V"
+                            }
+                          ],
+                          "usr": "s:s16_ValidUTF8BufferV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS8UTF8ViewV8IteratorV7_buffers06_ValidA6BufferVys6UInt64VGvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS8UTF8ViewV8IteratorV7_buffers06_ValidA6BufferVys6UInt64VGvp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 3,
+                  "hasStorage": true
+                },
+                {
+                  "kind": "Constructor",
+                  "name": "init",
+                  "printedName": "init(_:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Iterator",
+                      "printedName": "String.UTF8View.Iterator",
+                      "usr": "s:SS8UTF8ViewV8IteratorV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UTF8View",
+                      "printedName": "String.UTF8View",
+                      "usr": "s:SS8UTF8ViewV"
+                    }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:SS8UTF8ViewV8IteratorVyAdBcfc",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "next",
+                  "printedName": "next()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<UInt8>",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -86419,162 +100647,483 @@
                           "printedName": "UInt8",
                           "usr": "s:s5UInt8V"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     }
-                  ]
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS8UTF8ViewV8IteratorV4nexts5UInt8VSgyF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inline",
+                    "Inlinable"
+                  ],
+                  "mutating": true
                 }
+              ],
+              "declKind": "Struct",
+              "usr": "s:SS8UTF8ViewV8IteratorV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "IteratorProtocol"
               ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s12StaticStringVABycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "StaticString",
-              "printedName": "StaticString",
-              "usr": "s:s12StaticStringV"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(unicodeScalar:)",
-          "declKind": "Constructor",
-          "usr": "s:s12StaticStringV13unicodeScalarABBi32__tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "UsableFromInline"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "StaticString",
-              "printedName": "StaticString",
-              "usr": "s:s12StaticStringV"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Int32",
-              "printedName": "Int32",
+              "kind": "Function",
+              "name": "makeIterator",
+              "printedName": "makeIterator()",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "BuiltinInteger",
-                  "printedName": "Builtin.Int32"
+                  "name": "Iterator",
+                  "printedName": "String.UTF8View.Iterator",
+                  "usr": "s:SS8UTF8ViewV8IteratorV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS8UTF8ViewV12makeIteratorAB0D0VyF",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Var",
+              "name": "count",
+              "printedName": "count",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS8UTF8ViewV5countSivg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS8UTF8ViewV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "customMirror",
+              "printedName": "customMirror",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Mirror",
+                      "printedName": "Mirror",
+                      "usr": "s:s6MirrorV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS8UTF8ViewV12customMirrors0D0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS8UTF8ViewV12customMirrors0D0Vvp",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF8View",
+                  "printedName": "Substring.UTF8View",
+                  "usr": "s:Ss8UTF8ViewV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SS8UTF8ViewVySsAAVSnySS5IndexVGcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Available",
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "customPlaygroundQuickLook",
+              "printedName": "customPlaygroundQuickLook",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_PlaygroundQuickLook",
+                  "printedName": "_PlaygroundQuickLook",
+                  "usr": "s:s20_PlaygroundQuickLookO"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "_PlaygroundQuickLook",
+                      "printedName": "_PlaygroundQuickLook",
+                      "usr": "s:s20_PlaygroundQuickLookO"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS8UTF8ViewV25customPlaygroundQuickLooks01_deF0Ovg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS8UTF8ViewV25customPlaygroundQuickLooks01_deF0Ovp",
+              "moduleName": "Swift",
+              "deprecated": true,
+              "declAttributes": [
+                "Available"
               ]
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(unicodeScalarLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s12StaticStringV20unicodeScalarLiteralA2B_tcfc",
-          "location": "",
+          ],
+          "declKind": "Struct",
+          "usr": "s:SS8UTF8ViewV",
           "moduleName": "Swift",
           "declAttributes": [
-            "Transparent",
-            "Effects",
-            "Inlinable"
+            "FixedLayout"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "StaticString",
-              "printedName": "StaticString",
-              "usr": "s:s12StaticStringV"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "StaticString",
-              "printedName": "StaticString",
-              "usr": "s:s12StaticStringV"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(extendedGraphemeClusterLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s12StaticStringV30extendedGraphemeClusterLiteralA2B_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Effects",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "StaticString",
-              "printedName": "StaticString",
-              "usr": "s:s12StaticStringV"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "StaticString",
-              "printedName": "StaticString",
-              "usr": "s:s12StaticStringV"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(stringLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s12StaticStringV13stringLiteralA2B_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Effects",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "StaticString",
-              "printedName": "StaticString",
-              "usr": "s:s12StaticStringV"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "StaticString",
-              "printedName": "StaticString",
-              "usr": "s:s12StaticStringV"
-            }
+          "conformingProtocols": [
+            "BidirectionalCollection",
+            "CustomStringConvertible",
+            "CustomDebugStringConvertible",
+            "Collection",
+            "Sequence",
+            "_SwiftStringView",
+            "CustomReflectable",
+            "_CustomPlaygroundQuickLookable"
           ]
         },
         {
           "kind": "Var",
-          "name": "description",
-          "printedName": "description",
+          "name": "utf8",
+          "printedName": "utf8",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UTF8View",
+              "printedName": "String.UTF8View",
+              "usr": "s:SS8UTF8ViewV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF8View",
+                  "printedName": "String.UTF8View",
+                  "usr": "s:SS8UTF8ViewV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS4utf8SS8UTF8ViewVvg",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF8View",
+                  "printedName": "String.UTF8View",
+                  "usr": "s:SS8UTF8ViewV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS4utf8SS8UTF8ViewVvs",
+              "moduleName": "Swift",
+              "mutating": true
+            }
+          ],
           "declKind": "Var",
-          "usr": "s:s12StaticStringV11descriptionSSvp",
-          "location": "",
+          "usr": "s:SS4utf8SS8UTF8ViewVvp",
           "moduleName": "Swift",
           "declAttributes": [
             "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "utf8CString",
+          "printedName": "utf8CString",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ContiguousArray",
+              "printedName": "ContiguousArray<Int8>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int8",
+                  "printedName": "Int8",
+                  "usr": "s:s4Int8V"
+                }
+              ],
+              "usr": "s:s15ContiguousArrayV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ContiguousArray",
+                  "printedName": "ContiguousArray<Int8>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int8",
+                      "printedName": "Int8",
+                      "usr": "s:s4Int8V"
+                    }
+                  ],
+                  "usr": "s:s15ContiguousArrayV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS11utf8CStrings15ContiguousArrayVys4Int8VGvg",
+              "moduleName": "Swift"
+            }
           ],
+          "declKind": "Var",
+          "usr": "s:SS11utf8CStrings15ContiguousArrayVys4Int8VGvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UTF8View",
+              "printedName": "String.UTF8View",
+              "usr": "s:SS8UTF8ViewV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSyS2S8UTF8ViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Available",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSySSSscfc",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<String>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UTF8View",
+              "printedName": "Substring.UTF8View",
+              "usr": "s:Ss8UTF8ViewV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSySSSgSs8UTF8ViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<String>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UTF16View",
+              "printedName": "Substring.UTF16View",
+              "usr": "s:Ss9UTF16ViewV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSySSSgSs9UTF16ViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnicodeScalarView",
+              "printedName": "Substring.UnicodeScalarView",
+              "usr": "s:Ss17UnicodeScalarViewV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSySSSs17UnicodeScalarViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<String.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SSySsSnySS5IndexVGcip",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Available",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "characters",
+          "printedName": "characters",
           "children": [
             {
               "kind": "TypeNominal",
@@ -86586,10 +101135,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12StaticStringV11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -86597,18 +101142,87 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS10charactersSSvg",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS10charactersSSvs",
+              "moduleName": "Swift",
+              "mutating": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS10charactersSSvp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
-          "kind": "Var",
-          "name": "debugDescription",
-          "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s12StaticStringV16debugDescriptionSSvp",
-          "location": "",
+          "kind": "Function",
+          "name": "withMutableCharacters",
+          "printedName": "withMutableCharacters(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(inout String) -> τ_0_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "InOut",
+                  "printedName": "inout String"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS21withMutableCharactersyxxSSzXElF",
           "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(describing:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -86617,770 +101231,48 @@
               "usr": "s:SS"
             },
             {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12StaticStringV16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "StringLiteralType",
-          "printedName": "StringLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s12StaticStringV0B11LiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "StaticString",
-              "printedName": "StaticString",
-              "usr": "s:s12StaticStringV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "ExtendedGraphemeClusterLiteralType",
-          "printedName": "ExtendedGraphemeClusterLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s12StaticStringV34ExtendedGraphemeClusterLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "StaticString",
-              "printedName": "StaticString",
-              "usr": "s:s12StaticStringV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "UnicodeScalarLiteralType",
-          "printedName": "UnicodeScalarLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s12StaticStringV24UnicodeScalarLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "StaticString",
-              "printedName": "StaticString",
-              "usr": "s:s12StaticStringV"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s12StaticStringV12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12StaticStringV12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "Strideable",
-      "printedName": "Strideable",
-      "declKind": "Protocol",
-      "usr": "s:Sx",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Comparable, Self.Stride : Comparable, Self.Stride : SignedNumeric>",
-      "conformingProtocols": [
-        "Comparable",
-        "Equatable"
-      ],
-      "children": [
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(to:)",
-          "declKind": "Func",
-          "usr": "s:Sx8distance2to6StrideQzx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Strideable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Stride"
-            },
-            {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "advanced",
-          "printedName": "advanced(by:)",
-          "declKind": "Func",
-          "usr": "s:Sx8advanced2byx6StrideQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Strideable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DynamicSelf",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Stride"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "StrideToIterator",
-      "printedName": "StrideToIterator",
-      "declKind": "Struct",
-      "usr": "s:s16StrideToIteratorV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element where Element : Strideable>",
-      "conformingProtocols": [
-        "IteratorProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Function",
-          "name": "next",
-          "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s16StrideToIteratorV4nextxSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
+          "declKind": "Constructor",
+          "usr": "s:SS10describingSSx_tclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>"
         },
         {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s16StrideToIteratorV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(reflecting:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "StrideTo",
-      "printedName": "StrideTo",
-      "declKind": "Struct",
-      "usr": "s:s8StrideToV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element where Element : Strideable>",
-      "conformingProtocols": [
-        "Sequence",
-        "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Function",
-          "name": "makeIterator",
-          "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s8StrideToV12makeIterators0abD0VyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "StrideToIterator",
-              "printedName": "StrideToIterator<Element>",
-              "usr": "s:s16StrideToIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "underestimatedCount",
-          "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s8StrideToV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
             },
             {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s8StrideToV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Strideable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s8StrideToV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
-          "children": [
-            {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Element"
+              "printedName": "τ_0_0"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s8StrideToV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "StrideToIterator",
-              "printedName": "StrideToIterator<Element>",
-              "usr": "s:s16StrideToIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s8StrideToV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnySequence",
-              "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s8StrideToV12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s8StrideToV12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Strideable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "Function",
-      "name": "stride",
-      "printedName": "stride(from:to:by:)",
-      "declKind": "Func",
-      "usr": "s:s6stride4from2to2bys8StrideToVyxGx_x0E0QztSxRzlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Strideable>",
-      "declAttributes": [
-        "Inlinable"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "StrideTo",
-          "printedName": "StrideTo<T>",
-          "usr": "s:s8StrideToV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "DependentMember",
-          "printedName": "T.Stride"
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "StrideThroughIterator",
-      "printedName": "StrideThroughIterator",
-      "declKind": "Struct",
-      "usr": "s:s21StrideThroughIteratorV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element where Element : Strideable>",
-      "conformingProtocols": [
-        "IteratorProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Function",
-          "name": "next",
-          "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s21StrideThroughIteratorV4nextxSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s21StrideThroughIteratorV7Elementa",
-          "location": "",
+          "declKind": "Constructor",
+          "usr": "s:SS10reflectingSSx_tclufc",
           "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
+          "genericSig": "<τ_0_0>"
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "StrideThrough",
-      "printedName": "StrideThrough",
-      "declKind": "Struct",
-      "usr": "s:s13StrideThroughV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element where Element : Strideable>",
-      "conformingProtocols": [
-        "Sequence",
-        "CustomReflectable"
       ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Function",
-          "name": "makeIterator",
-          "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s13StrideThroughV12makeIterators0abD0VyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "StrideThroughIterator",
-              "printedName": "StrideThroughIterator<Element>",
-              "usr": "s:s21StrideThroughIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "underestimatedCount",
-          "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s13StrideThroughV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13StrideThroughV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Strideable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s13StrideThroughV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s13StrideThroughV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "StrideThroughIterator",
-              "printedName": "StrideThroughIterator<Element>",
-              "usr": "s:s21StrideThroughIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s13StrideThroughV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnySequence",
-              "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s13StrideThroughV12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13StrideThroughV12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Strideable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "Function",
-      "name": "stride",
-      "printedName": "stride(from:through:by:)",
-      "declKind": "Func",
-      "usr": "s:s6stride4from7through2bys13StrideThroughVyxGx_x0E0QztSxRzlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Strideable>",
-      "declAttributes": [
-        "Inlinable"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "StrideThrough",
-          "printedName": "StrideThrough<T>",
-          "usr": "s:s13StrideThroughV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "DependentMember",
-          "printedName": "T.Stride"
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "String",
-      "printedName": "String",
       "declKind": "Struct",
       "usr": "s:SS",
-      "location": "",
       "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
-        "Decodable",
         "Encodable",
+        "Decodable",
         "CustomReflectable",
         "_CustomPlaygroundQuickLookable",
         "TextOutputStream",
@@ -87406,503 +101298,460 @@
         "RangeReplaceableCollection",
         "LosslessStringConvertible",
         "MirrorPath"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "StringProtocol",
+      "printedName": "StringProtocol",
       "children": [
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:S2Sycfc",
-          "location": "",
+          "kind": "AssociatedType",
+          "name": "UTF8View",
+          "printedName": "UTF8View",
+          "declKind": "AssociatedType",
+          "usr": "s:Sy8UTF8ViewQa",
           "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
+          "protocolReq": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSSJcfc",
-          "location": "",
+          "kind": "AssociatedType",
+          "name": "UTF16View",
+          "printedName": "UTF16View",
+          "declKind": "AssociatedType",
+          "usr": "s:Sy9UTF16ViewQa",
           "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            }
-          ]
+          "protocolReq": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:SS4fromSSs7Decoder_p_tKcfc",
-          "location": "",
+          "kind": "AssociatedType",
+          "name": "UnicodeScalarView",
+          "printedName": "UnicodeScalarView",
+          "declKind": "AssociatedType",
+          "usr": "s:Sy17UnicodeScalarViewQa",
           "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:Sy11SubSequenceQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "Var",
+          "name": "utf8",
+          "printedName": "utf8",
+          "children": [
             {
               "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
+              "name": "DependentMember",
+              "printedName": "τ_0_0.UTF8View"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.UTF8View"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sy4utf88UTF8ViewQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : StringProtocol>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sy4utf88UTF8ViewQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "utf16",
+          "printedName": "utf16",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.UTF16View"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.UTF16View"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sy5utf169UTF16ViewQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : StringProtocol>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sy5utf169UTF16ViewQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "unicodeScalars",
+          "printedName": "unicodeScalars",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "τ_0_0.UnicodeScalarView"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.UnicodeScalarView"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sy14unicodeScalars17UnicodeScalarViewQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : StringProtocol>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sy14unicodeScalars17UnicodeScalarViewQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:SS6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "name": "hasPrefix",
+          "printedName": "hasPrefix(_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(cString:)",
-          "declKind": "Constructor",
-          "usr": "s:SS7cStringSSSPys4Int8VG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafePointer",
-              "printedName": "UnsafePointer<CChar>",
-              "usr": "s:SP",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "CChar",
-                  "printedName": "CChar",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int8",
-                      "printedName": "Int8",
-                      "usr": "s:s4Int8V"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(cString:)",
-          "declKind": "Constructor",
-          "usr": "s:SS7cStringSSSPys5UInt8VG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafePointer",
-              "printedName": "UnsafePointer<UInt8>",
-              "usr": "s:SP",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt8",
-                  "printedName": "UInt8",
-                  "usr": "s:s5UInt8V"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(validatingUTF8:)",
-          "declKind": "Constructor",
-          "usr": "s:SS14validatingUTF8SSSgSPys4Int8VG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "String?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafePointer",
-              "printedName": "UnsafePointer<CChar>",
-              "usr": "s:SP",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "CChar",
-                  "printedName": "CChar",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int8",
-                      "printedName": "Int8",
-                      "usr": "s:s4Int8V"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "decodeCString",
-          "printedName": "decodeCString(_:as:repairingInvalidCodeUnits:)",
-          "declKind": "Func",
-          "usr": "s:SS13decodeCString_2as25repairingInvalidCodeUnitsSS6result_Sb11repairsMadetSgSPy0F4UnitQzGSg_xmSbts16_UnicodeEncodingRzlFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Encoding where Encoding : _UnicodeEncoding>",
-          "static": true,
-          "declAttributes": [
-            "Specialize",
-            "Specialize"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "(result: String, repairsMade: Bool)?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(result: String, repairsMade: Bool)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "String",
-                      "printedName": "String",
-                      "usr": "s:SS"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Bool",
-                      "printedName": "Bool",
-                      "usr": "s:Sb"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UnsafePointer<Encoding.CodeUnit>?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafePointer",
-                  "printedName": "UnsafePointer<Encoding.CodeUnit>",
-                  "usr": "s:SP",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Encoding.CodeUnit"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "Encoding.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Encoding"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
               "name": "Bool",
               "printedName": "Bool",
-              "hasDefaultArg": true,
               "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sy9hasPrefixySbSSF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : StringProtocol>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "hasSuffix",
+          "printedName": "hasSuffix(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sy9hasSuffixySbSSF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : StringProtocol>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "lowercased",
+          "printedName": "lowercased()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sy10lowercasedSSyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : StringProtocol>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "uppercased",
+          "printedName": "uppercased()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sy10uppercasedSSyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : StringProtocol>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(decoding:as:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_1_1.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_1"
+                }
+              ]
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sy8decoding2asxqd___qd_0_mtcSlRd__s16_UnicodeEncodingRd_0_8CodeUnitQyd_0_7ElementRtd__r0_lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0, τ_1_1 where τ_0_0 : StringProtocol, τ_1_0 : Collection, τ_1_1 : _UnicodeEncoding, τ_1_0.Element == τ_1_1.CodeUnit>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(cString:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafePointer",
+              "printedName": "UnsafePointer<Int8>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int8",
+                  "printedName": "Int8",
+                  "usr": "s:s4Int8V"
+                }
+              ],
+              "usr": "s:SP"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sy7cStringxSPys4Int8VG_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : StringProtocol>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(decodingCString:as:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafePointer",
+              "printedName": "UnsafePointer<τ_1_0.CodeUnit>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_1_0.CodeUnit"
+                }
+              ],
+              "usr": "s:SP"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_1_0.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                }
+              ]
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sy15decodingCString2asxSPy8CodeUnitQyd__G_qd__mtcs16_UnicodeEncodingRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : StringProtocol, τ_1_0 : _UnicodeEncoding>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "withCString",
           "printedName": "withCString(_:)",
-          "declKind": "Func",
-          "usr": "s:SS11withCStringyxxSPys4Int8VGKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Result>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Result"
+              "printedName": "τ_1_0"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(UnsafePointer<Int8>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(UnsafePointer<Int8>) throws -> τ_1_0",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Result"
+                  "printedName": "τ_1_0"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafePointer<Int8>)",
-                  "usr": "s:SP",
+                  "name": "UnsafePointer",
+                  "printedName": "UnsafePointer<Int8>",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "UnsafePointer",
-                      "printedName": "UnsafePointer<Int8>",
-                      "usr": "s:SP",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Int8",
-                          "printedName": "Int8",
-                          "usr": "s:s4Int8V"
-                        }
-                      ]
+                      "name": "Int8",
+                      "printedName": "Int8",
+                      "usr": "s:s4Int8V"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:SS12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customPlaygroundQuickLook",
-          "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:SS25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "_PlaygroundQuickLook",
-              "printedName": "_PlaygroundQuickLook",
-              "usr": "s:s20_PlaygroundQuickLookO"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "_PlaygroundQuickLook",
-                  "printedName": "_PlaygroundQuickLook",
-                  "usr": "s:s20_PlaygroundQuickLookO"
-                }
-              ]
-            }
-          ]
+          "declKind": "Func",
+          "usr": "s:Sy11withCStringyqd__qd__SPys4Int8VGKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : StringProtocol>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
-          "name": "write",
-          "printedName": "write(_:)",
-          "declKind": "Func",
-          "usr": "s:SS5writeyySSF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "name": "withCString",
+          "printedName": "withCString(encodedAs:_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "write",
-          "printedName": "write(to:)",
-          "declKind": "Func",
-          "usr": "s:SS5write2toyxz_ts16TextOutputStreamRzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Target where Target : TextOutputStream>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Target"
+              "printedName": "τ_1_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_1_1.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_1"
+                }
+              ]
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafePointer<τ_1_1.CodeUnit>) throws -> τ_1_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafePointer",
+                  "printedName": "UnsafePointer<τ_1_1.CodeUnit>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_1_1.CodeUnit"
+                    }
+                  ],
+                  "usr": "s:SP"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sy11withCString9encodedAs_qd__qd_0_m_qd__SPy8CodeUnitQyd_0_GKXEtKs16_UnicodeEncodingRd_0_r0_lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0, τ_1_1 where τ_0_0 : StringProtocol, τ_1_1 : _UnicodeEncoding>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SS4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -87915,1626 +101764,19 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "hashValue",
-          "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SS9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(decoding:as:)",
-          "declKind": "Constructor",
-          "usr": "s:SS8decoding2asSSx_q_mtcSlRzs16_UnicodeEncodingR_8CodeUnitQy_7ElementRtzr0_lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<C, Encoding where C : Collection, Encoding : _UnicodeEncoding, C.Element == Encoding.CodeUnit>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "C"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "Encoding.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Encoding"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(decodingCString:as:)",
-          "declKind": "Constructor",
-          "usr": "s:SS15decodingCString2asSSSPy8CodeUnitQzG_xmtcs16_UnicodeEncodingRzlufc",
-          "location": "",
+          "declKind": "Func",
+          "usr": "s:SysE4hash4intoys6HasherVz_tF",
           "moduleName": "Swift",
-          "genericSig": "<Encoding where Encoding : _UnicodeEncoding>",
+          "genericSig": "<τ_0_0 where τ_0_0 : StringProtocol>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafePointer",
-              "printedName": "UnsafePointer<Encoding.CodeUnit>",
-              "usr": "s:SP",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Encoding.CodeUnit"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "Encoding.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Encoding"
-                }
-              ]
-            }
           ]
         },
         {
           "kind": "Function",
-          "name": "withCString",
-          "printedName": "withCString(encodedAs:_:)",
-          "declKind": "Func",
-          "usr": "s:SS11withCString9encodedAs_xq_m_xSPy8CodeUnitQy_GKXEtKs16_UnicodeEncodingR_r0_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Result, TargetEncoding where TargetEncoding : _UnicodeEncoding>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Result"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "TargetEncoding.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "TargetEncoding"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafePointer<TargetEncoding.CodeUnit>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Result"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafePointer<TargetEncoding.CodeUnit>)",
-                  "usr": "s:SP",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafePointer",
-                      "printedName": "UnsafePointer<TargetEncoding.CodeUnit>",
-                      "usr": "s:SP",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "DependentMember",
-                          "printedName": "TargetEncoding.CodeUnit"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSs7UnicodeO6ScalarVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Scalar",
-              "printedName": "Unicode.Scalar",
-              "usr": "s:s7UnicodeO6ScalarV"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(stringLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:SS13stringLiteralS2S_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "StringLiteralType",
-          "printedName": "StringLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:SS17StringLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "ExtendedGraphemeClusterLiteralType",
-          "printedName": "ExtendedGraphemeClusterLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:SS34ExtendedGraphemeClusterLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "UnicodeScalarLiteralType",
-          "printedName": "UnicodeScalarLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:SS24UnicodeScalarLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "debugDescription",
-          "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:SS16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "append",
-          "printedName": "append(_:)",
-          "declKind": "Func",
-          "usr": "s:SS6appendyySSF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "lowercased",
-          "printedName": "lowercased()",
-          "declKind": "Func",
-          "usr": "s:SS10lowercasedSSyF",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "uppercased",
-          "printedName": "uppercased()",
-          "declKind": "Func",
-          "usr": "s:SS10uppercasedSSyF",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSxcs25LosslessStringConvertibleRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T where T : LosslessStringConvertible>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "description",
-          "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:SS11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "IndexDistance",
-          "printedName": "IndexDistance",
-          "declKind": "TypeAlias",
-          "usr": "s:SS13IndexDistancea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:SS11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:SS10startIndexSS0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "String.Index",
-              "usr": "s:SS5IndexV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS10startIndexSS0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:SS8endIndexSS0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "String.Index",
-              "usr": "s:SS5IndexV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS8endIndexSS0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "count",
-          "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:SS5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:SS5index5afterSS5IndexVAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "String.Index",
-              "usr": "s:SS5IndexV"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "String.Index",
-              "usr": "s:SS5IndexV"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:SS5index6beforeSS5IndexVAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "String.Index",
-              "usr": "s:SS5IndexV"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "String.Index",
-              "usr": "s:SS5IndexV"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SS5index_8offsetBySS5IndexVAD_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "String.Index",
-              "usr": "s:SS5IndexV"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "String.Index",
-              "usr": "s:SS5IndexV"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "IndexDistance",
-              "printedName": "String.IndexDistance",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SS5index_8offsetBy07limitedC0SS5IndexVSgAE_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "String.Index?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "String.Index",
-              "usr": "s:SS5IndexV"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "IndexDistance",
-              "printedName": "String.IndexDistance",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "String.Index",
-              "usr": "s:SS5IndexV"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SS8distance4from2toSiSS5IndexV_AEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "IndexDistance",
-              "printedName": "String.IndexDistance",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "String.Index",
-              "usr": "s:SS5IndexV"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "String.Index",
-              "usr": "s:SS5IndexV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:SS7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:SS8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "IndexingIterator",
-              "printedName": "IndexingIterator<String>",
-              "usr": "s:s16IndexingIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:SS7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DefaultIndices",
-              "printedName": "DefaultIndices<String>",
-              "usr": "s:SI",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeDecl",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "Struct",
-          "usr": "s:SS5IndexV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "Equatable",
-            "Comparable",
-            "Hashable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "Function",
-              "name": "hash",
-              "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:SS5IndexV4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Hasher",
-                  "printedName": "Hasher",
-                  "usr": "s:s6HasherV"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "hashValue",
-              "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:SS5IndexV9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS5IndexV9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Constructor",
-              "name": "init",
-              "printedName": "init(encodedOffset:transcodedOffset:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV13encodedOffset010transcodedC0ABSi_Sitcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable",
-                "Inline"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Constructor",
-              "name": "init",
-              "printedName": "init(from:adjustingEncodedOffsetBy:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV4from24adjustingEncodedOffsetByA2B_Sitcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable",
-                "Inline"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Constructor",
-              "name": "init",
-              "printedName": "init(encodedOffset:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV13encodedOffsetABSi_tcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Constructor",
-              "name": "init",
-              "printedName": "init(encodedOffset:transcodedOffset:buffer:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV13encodedOffset010transcodedC06bufferABSi_Sis16_ValidUTF8BufferVys6UInt32VGtcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "_UTF8Buffer",
-                  "printedName": "String.Index._UTF8Buffer",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "_ValidUTF8Buffer",
-                      "printedName": "_ValidUTF8Buffer<UInt32>",
-                      "usr": "s:s16_ValidUTF8BufferV",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "UInt32",
-                          "printedName": "UInt32",
-                          "usr": "s:s6UInt32V"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Constructor",
-              "name": "init",
-              "printedName": "init(encodedOffset:characterStride:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV13encodedOffset15characterStrideABSi_Sitcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "encodedOffset",
-              "printedName": "encodedOffset",
-              "declKind": "Var",
-              "usr": "s:SS5IndexV13encodedOffsetSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS5IndexV13encodedOffsetSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Constructor",
-              "name": "init",
-              "printedName": "init(_:within:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV_6withinABSgAB_SStcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "samePosition",
-              "printedName": "samePosition(in:)",
-              "declKind": "Func",
-              "usr": "s:SS5IndexV12samePosition2inABSgSS8UTF8ViewV_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF8View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF8View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "UTF8View",
-                  "printedName": "String.UTF8View",
-                  "usr": "s:SS8UTF8ViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "samePosition",
-              "printedName": "samePosition(in:)",
-              "declKind": "Func",
-              "usr": "s:SS5IndexV12samePosition2inABSgSS9UTF16ViewV_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF16View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "UTF16View",
-                  "printedName": "String.UTF16View",
-                  "usr": "s:SS9UTF16ViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Constructor",
-              "name": "init",
-              "printedName": "init(_:within:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV_6withinABSgAB_SS17UnicodeScalarViewVtcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "UTF16Index",
-                  "printedName": "String.UTF16Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnicodeScalarView",
-                  "printedName": "String.UnicodeScalarView",
-                  "usr": "s:SS17UnicodeScalarViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "samePosition",
-              "printedName": "samePosition(in:)",
-              "declKind": "Func",
-              "usr": "s:SS5IndexV12samePosition2inABSgSS_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            },
-            {
-              "kind": "Constructor",
-              "name": "init",
-              "printedName": "init(_:within:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV_6withinABSgAB_SS9UTF16ViewVtcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "UTF16View",
-                  "printedName": "String.UTF16View",
-                  "usr": "s:SS9UTF16ViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "samePosition",
-              "printedName": "samePosition(in:)",
-              "declKind": "Func",
-              "usr": "s:SS5IndexV12samePosition2inABSgSS17UnicodeScalarViewV_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UnicodeScalarIndex?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "UnicodeScalarIndex",
-                      "printedName": "String.UnicodeScalarIndex",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnicodeScalarView",
-                  "printedName": "String.UnicodeScalarView",
-                  "usr": "s:SS17UnicodeScalarViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Constructor",
-              "name": "init",
-              "printedName": "init(_:within:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV_6withinABSgAB_SS8UTF8ViewVtcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "UTF8View",
-                  "printedName": "String.UTF8View",
-                  "usr": "s:SS8UTF8ViewV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(stringInterpolation:)",
-          "declKind": "Constructor",
-          "usr": "s:SS19stringInterpolationS2Sd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Effects",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "[String]",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(stringInterpolationSegment:)",
-          "declKind": "Constructor",
-          "usr": "s:SS26stringInterpolationSegmentSSx_tclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(stringInterpolationSegment:)",
-          "declKind": "Constructor",
-          "usr": "s:SS26stringInterpolationSegmentSSx_tcs20TextOutputStreamableRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T where T : TextOutputStreamable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(stringInterpolationSegment:)",
-          "declKind": "Constructor",
-          "usr": "s:SS26stringInterpolationSegmentSSx_tcs23CustomStringConvertibleRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T where T : CustomStringConvertible>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(stringInterpolationSegment:)",
-          "declKind": "Constructor",
-          "usr": "s:SS26stringInterpolationSegmentSSx_tcs23CustomStringConvertibleRzs20TextOutputStreamableRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T where T : CustomStringConvertible, T : TextOutputStreamable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(repeating:count:)",
-          "declKind": "Constructor",
-          "usr": "s:SS9repeating5countS2S_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isEmpty",
-          "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:SS7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "name": "==",
+          "printedName": "==(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -89543,32 +101785,184 @@
               "usr": "s:Sb"
             },
             {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SysE2eeoiySbx_qd__tSyRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : StringProtocol, τ_1_0 : StringProtocol>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "!=",
+          "printedName": "!=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SysE2neoiySbx_qd__tSyRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : StringProtocol, τ_1_0 : StringProtocol>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SysE1loiySbx_qd__tSyRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : StringProtocol, τ_1_0 : StringProtocol>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SysE1goiySbx_qd__tSyRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : StringProtocol, τ_1_0 : StringProtocol>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SysE2leoiySbx_qd__tSyRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : StringProtocol, τ_1_0 : StringProtocol>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SysE2geoiySbx_qd__tSyRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : StringProtocol, τ_1_0 : StringProtocol>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hasPrefix",
           "printedName": "hasPrefix(_:)",
-          "declKind": "Func",
-          "usr": "s:SS9hasPrefixySbSSF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -89578,20 +101972,22 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SysE9hasPrefixySbqd__SyRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : StringProtocol, τ_1_0 : StringProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hasSuffix",
           "printedName": "hasSuffix(_:)",
-          "declKind": "Func",
-          "usr": "s:SS9hasSuffixySbSSF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -89601,4349 +101997,23 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:radix:uppercase:)",
-          "declKind": "Constructor",
-          "usr": "s:SS_5radix9uppercaseSSx_SiSbtcSzRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T where T : BinaryInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "hasDefaultArg": true,
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "hasDefaultArg": true,
-              "usr": "s:Sb"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(repeating:count:)",
-          "declKind": "Constructor",
-          "usr": "s:SS9repeating5countSSSJ_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSxcs25LosslessStringConvertibleRzSTRzSJ7ElementSTRtzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : LosslessStringConvertible, S : Sequence, S.Element == Character>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSxcSTRzSJ7ElementRtzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : Sequence, S.Element == Character>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "reserveCapacity",
-          "printedName": "reserveCapacity(_:)",
           "declKind": "Func",
-          "usr": "s:SS15reserveCapacityyySiF",
-          "location": "",
+          "usr": "s:SysE9hasSuffixySbqd__SyRd__lF",
           "moduleName": "Swift",
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "append",
-          "printedName": "append(_:)",
-          "declKind": "Func",
-          "usr": "s:SS6appendyySJF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "append",
-          "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:SS6append10contentsOfySS_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "append",
-          "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:SS6append10contentsOfySs_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "append",
-          "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:SS6append10contentsOfyx_tSTRzSJ7ElementRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : Sequence, S.Element == Character>",
-          "mutating": true,
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : StringProtocol, τ_1_0 : StringProtocol>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "replaceSubrange",
-          "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:SS15replaceSubrange_4withySnySS5IndexVG_xtSlRzSJ7ElementRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<C where C : Collection, C.Element == Character>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<String.Index>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "C"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "insert",
-          "printedName": "insert(_:at:)",
-          "declKind": "Func",
-          "usr": "s:SS6insert_2atySJ_SS5IndexVtF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "String.Index",
-              "usr": "s:SS5IndexV"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "insert",
-          "printedName": "insert(contentsOf:at:)",
-          "declKind": "Func",
-          "usr": "s:SS6insert10contentsOf2atyx_SS5IndexVtSlRzSJ7ElementRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : Collection, S.Element == Character>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "String.Index",
-              "usr": "s:SS5IndexV"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "remove",
-          "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:SS6remove2atSJSS5IndexV_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "String.Index",
-              "usr": "s:SS5IndexV"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "removeSubrange",
-          "printedName": "removeSubrange(_:)",
-          "declKind": "Func",
-          "usr": "s:SS14removeSubrangeyySnySS5IndexVGF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<String.Index>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "removeAll",
-          "printedName": "removeAll(keepingCapacity:)",
-          "declKind": "Func",
-          "usr": "s:SS9removeAll15keepingCapacityySb_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "hasDefaultArg": true,
-              "usr": "s:Sb"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "max",
-          "printedName": "max(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SS3maxyxx_xtSLRzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T where T : Comparable>",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "min",
-          "printedName": "min(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SS3minyxx_xtSLRzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T where T : Comparable>",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "TypeDecl",
-          "name": "UnicodeScalarView",
-          "printedName": "UnicodeScalarView",
-          "declKind": "Struct",
-          "usr": "s:SS17UnicodeScalarViewV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "CustomStringConvertible",
-            "CustomDebugStringConvertible",
-            "Collection",
-            "Sequence",
-            "_SwiftStringView",
-            "RangeReplaceableCollection",
-            "CustomReflectable",
-            "_CustomPlaygroundQuickLookable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:SS17UnicodeScalarViewV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "startIndex",
-              "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:SS17UnicodeScalarViewV10startIndexSS0E0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS17UnicodeScalarViewV10startIndexSS0E0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UnicodeScalarView.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "endIndex",
-              "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:SS17UnicodeScalarViewV8endIndexSS0E0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS17UnicodeScalarViewV8endIndexSS0E0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UnicodeScalarView.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV5index5afterSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV5index6beforeSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeDecl",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "Struct",
-              "usr": "s:SS17UnicodeScalarViewV8IteratorV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "IteratorProtocol"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
-              "children": [
-                {
-                  "kind": "Constructor",
-                  "name": "init",
-                  "printedName": "init(_:)",
-                  "declKind": "Constructor",
-                  "usr": "s:SS17UnicodeScalarViewV8IteratorVyADs11_StringGutsVcfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Iterator",
-                      "printedName": "String.UnicodeScalarView.Iterator",
-                      "usr": "s:SS17UnicodeScalarViewV8IteratorV"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "_StringGuts",
-                      "printedName": "_StringGuts",
-                      "usr": "s:s11_StringGutsV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Function",
-                  "name": "next",
-                  "printedName": "next()",
-                  "declKind": "Func",
-                  "usr": "s:SS17UnicodeScalarViewV8IteratorV4nexts0A0O0B0VSgyF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "mutating": true,
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Optional",
-                      "printedName": "Unicode.Scalar?",
-                      "usr": "s:Sq",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Scalar",
-                          "printedName": "Unicode.Scalar",
-                          "usr": "s:s7UnicodeO6ScalarV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeAlias",
-                  "name": "Element",
-                  "printedName": "Element",
-                  "declKind": "TypeAlias",
-                  "usr": "s:SS17UnicodeScalarViewV8IteratorV7Elementa",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Scalar",
-                      "printedName": "Unicode.Scalar",
-                      "usr": "s:s7UnicodeO6ScalarV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "makeIterator",
-              "printedName": "makeIterator()",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV12makeIteratorAB0E0VyF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "String.UnicodeScalarView.Iterator",
-                  "usr": "s:SS17UnicodeScalarViewV8IteratorV"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "description",
-              "printedName": "description",
-              "declKind": "Var",
-              "usr": "s:SS17UnicodeScalarViewV11descriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS17UnicodeScalarViewV11descriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "String",
-                      "printedName": "String",
-                      "usr": "s:SS"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "debugDescription",
-              "printedName": "debugDescription",
-              "declKind": "Var",
-              "usr": "s:SS17UnicodeScalarViewV16debugDescriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS17UnicodeScalarViewV16debugDescriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "String",
-                      "printedName": "String",
-                      "usr": "s:SS"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:SS17UnicodeScalarViewV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Scalar",
-                  "printedName": "Unicode.Scalar",
-                  "usr": "s:s7UnicodeO6ScalarV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:SS17UnicodeScalarViewV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DefaultIndices",
-                  "printedName": "DefaultIndices<String.UnicodeScalarView>",
-                  "usr": "s:SI",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnicodeScalarView",
-                      "printedName": "String.UnicodeScalarView",
-                      "usr": "s:SS17UnicodeScalarViewV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Constructor",
-              "name": "init",
-              "printedName": "init()",
-              "declKind": "Constructor",
-              "usr": "s:SS17UnicodeScalarViewVABycfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnicodeScalarView",
-                  "printedName": "String.UnicodeScalarView",
-                  "usr": "s:SS17UnicodeScalarViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "reserveCapacity",
-              "printedName": "reserveCapacity(_:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV15reserveCapacityyySiF",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "append",
-              "printedName": "append(_:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV6appendyys0A0O0B0VF",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Scalar",
-                  "printedName": "Unicode.Scalar",
-                  "usr": "s:s7UnicodeO6ScalarV"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "append",
-              "printedName": "append(contentsOf:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV6append10contentsOfyx_tSTRzs0A0O0B0V7ElementRtzlF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<S where S : Sequence, S.Element == Unicode.Scalar>",
-              "mutating": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "S"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "replaceSubrange",
-              "printedName": "replaceSubrange(_:with:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV15replaceSubrange_4withySnySS5IndexVG_xtSlRzs0A0O0B0V7ElementRtzlF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<C where C : Collection, C.Element == Unicode.Scalar>",
-              "mutating": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<String.UnicodeScalarView.Index>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UnicodeScalarView.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "C"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "customMirror",
-              "printedName": "customMirror",
-              "declKind": "Var",
-              "usr": "s:SS17UnicodeScalarViewV12customMirrors0E0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS17UnicodeScalarViewV12customMirrors0E0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Mirror",
-                      "printedName": "Mirror",
-                      "usr": "s:s6MirrorV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:SS17UnicodeScalarViewV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnicodeScalarView",
-                  "printedName": "Substring.UnicodeScalarView",
-                  "usr": "s:Ss17UnicodeScalarViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "customPlaygroundQuickLook",
-              "printedName": "customPlaygroundQuickLook",
-              "declKind": "Var",
-              "usr": "s:SS17UnicodeScalarViewV25customPlaygroundQuickLooks01_efG0Ovp",
-              "location": "",
-              "moduleName": "Swift",
-              "deprecated": true,
-              "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "_PlaygroundQuickLook",
-                  "printedName": "_PlaygroundQuickLook",
-                  "usr": "s:s20_PlaygroundQuickLookO"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS17UnicodeScalarViewV25customPlaygroundQuickLooks01_efG0Ovg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "_PlaygroundQuickLook",
-                      "printedName": "_PlaygroundQuickLook",
-                      "usr": "s:s20_PlaygroundQuickLookO"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV5index5afterSS5IndexVAFSg_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UnicodeScalarView.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UnicodeScalarView.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(_:offsetBy:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV5index_8offsetBySS5IndexVAFSg_SitF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UnicodeScalarView.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UnicodeScalarView.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "distance",
-              "printedName": "distance(from:to:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV8distance4from2toSiSS5IndexVSg_AHtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UnicodeScalarView.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UnicodeScalarView.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UnicodeScalarView.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UnicodeScalarView.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "popFirst",
-              "printedName": "popFirst()",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV8popFirsts0A0O0B0VSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "deprecated": true,
-              "mutating": true,
-              "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UnicodeScalarView.Element?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "String.UnicodeScalarView.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Scalar",
-                          "printedName": "Unicode.Scalar",
-                          "usr": "s:s7UnicodeO6ScalarV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSyS2S17UnicodeScalarViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnicodeScalarView",
-              "printedName": "String.UnicodeScalarView",
-              "usr": "s:SS17UnicodeScalarViewV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "UnicodeScalarIndex",
-          "printedName": "UnicodeScalarIndex",
-          "declKind": "TypeAlias",
-          "usr": "s:SS18UnicodeScalarIndexa",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "String.UnicodeScalarView.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "unicodeScalars",
-          "printedName": "unicodeScalars",
-          "declKind": "Var",
-          "usr": "s:SS14unicodeScalarsSS17UnicodeScalarViewVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnicodeScalarView",
-              "printedName": "String.UnicodeScalarView",
-              "usr": "s:SS17UnicodeScalarViewV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS14unicodeScalarsSS17UnicodeScalarViewVvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnicodeScalarView",
-                  "printedName": "String.UnicodeScalarView",
-                  "usr": "s:SS17UnicodeScalarViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Setter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS14unicodeScalarsSS17UnicodeScalarViewVvs",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnicodeScalarView",
-                  "printedName": "String.UnicodeScalarView",
-                  "usr": "s:SS17UnicodeScalarViewV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeDecl",
-          "name": "UTF16View",
-          "printedName": "UTF16View",
-          "declKind": "Struct",
-          "usr": "s:SS9UTF16ViewV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "CustomStringConvertible",
-            "CustomDebugStringConvertible",
-            "Collection",
-            "Sequence",
-            "_SwiftStringView",
-            "CustomReflectable",
-            "_CustomPlaygroundQuickLookable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:SS9UTF16ViewV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "startIndex",
-              "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:SS9UTF16ViewV10startIndexSS0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS9UTF16ViewV10startIndexSS0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "endIndex",
-              "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:SS9UTF16ViewV8endIndexSS0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS9UTF16ViewV8endIndexSS0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeDecl",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "Struct",
-              "usr": "s:SS9UTF16ViewV7IndicesV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "BidirectionalCollection",
-                "Collection",
-                "Sequence"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
-              "children": [
-                {
-                  "kind": "TypeAlias",
-                  "name": "Index",
-                  "printedName": "Index",
-                  "declKind": "TypeAlias",
-                  "usr": "s:SS9UTF16ViewV7IndicesV5Indexa",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeAlias",
-                  "name": "Indices",
-                  "printedName": "Indices",
-                  "declKind": "TypeAlias",
-                  "usr": "s:SS9UTF16ViewV7IndicesVACa",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Indices",
-                      "printedName": "String.UTF16View.Indices",
-                      "usr": "s:SS9UTF16ViewV7IndicesV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeAlias",
-                  "name": "SubSequence",
-                  "printedName": "SubSequence",
-                  "declKind": "TypeAlias",
-                  "usr": "s:SS9UTF16ViewV7IndicesV11SubSequencea",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Indices",
-                      "printedName": "String.UTF16View.Indices",
-                      "usr": "s:SS9UTF16ViewV7IndicesV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Var",
-                  "name": "startIndex",
-                  "printedName": "startIndex",
-                  "declKind": "Var",
-                  "usr": "s:SS9UTF16ViewV7IndicesV10startIndexSS0E0Vvp",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "Getter",
-                      "name": "_",
-                      "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:SS9UTF16ViewV7IndicesV10startIndexSS0E0Vvg",
-                      "location": "",
-                      "moduleName": "Swift",
-                      "children": [
-                        {
-                          "kind": "TypeNameAlias",
-                          "name": "Index",
-                          "printedName": "String.UTF16View.Indices.Index",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Index",
-                              "printedName": "String.Index",
-                              "usr": "s:SS5IndexV"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "Var",
-                  "name": "endIndex",
-                  "printedName": "endIndex",
-                  "declKind": "Var",
-                  "usr": "s:SS9UTF16ViewV7IndicesV8endIndexSS0E0Vvp",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "Getter",
-                      "name": "_",
-                      "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:SS9UTF16ViewV7IndicesV8endIndexSS0E0Vvg",
-                      "location": "",
-                      "moduleName": "Swift",
-                      "children": [
-                        {
-                          "kind": "TypeNameAlias",
-                          "name": "Index",
-                          "printedName": "String.UTF16View.Indices.Index",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Index",
-                              "printedName": "String.Index",
-                              "usr": "s:SS5IndexV"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "Var",
-                  "name": "indices",
-                  "printedName": "indices",
-                  "declKind": "Var",
-                  "usr": "s:SS9UTF16ViewV7IndicesV7indicesADvp",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Indices",
-                      "printedName": "String.UTF16View.Indices.Indices",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Indices",
-                          "printedName": "String.UTF16View.Indices",
-                          "usr": "s:SS9UTF16ViewV7IndicesV"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "Getter",
-                      "name": "_",
-                      "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:SS9UTF16ViewV7IndicesV7indicesADvg",
-                      "location": "",
-                      "moduleName": "Swift",
-                      "children": [
-                        {
-                          "kind": "TypeNameAlias",
-                          "name": "Indices",
-                          "printedName": "String.UTF16View.Indices.Indices",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Indices",
-                              "printedName": "String.UTF16View.Indices",
-                              "usr": "s:SS9UTF16ViewV7IndicesV"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "Function",
-                  "name": "index",
-                  "printedName": "index(after:)",
-                  "declKind": "Func",
-                  "usr": "s:SS9UTF16ViewV7IndicesV5index5afterSS5IndexVAH_tF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "Function",
-                  "name": "formIndex",
-                  "printedName": "formIndex(after:)",
-                  "declKind": "Func",
-                  "usr": "s:SS9UTF16ViewV7IndicesV9formIndex5afterySS0E0Vz_tF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Void",
-                      "printedName": "()"
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "Function",
-                  "name": "index",
-                  "printedName": "index(before:)",
-                  "declKind": "Func",
-                  "usr": "s:SS9UTF16ViewV7IndicesV5index6beforeSS5IndexVAH_tF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "Function",
-                  "name": "formIndex",
-                  "printedName": "formIndex(before:)",
-                  "declKind": "Func",
-                  "usr": "s:SS9UTF16ViewV7IndicesV9formIndex6beforeySS0E0Vz_tF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Void",
-                      "printedName": "()"
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "Function",
-                  "name": "index",
-                  "printedName": "index(_:offsetBy:)",
-                  "declKind": "Func",
-                  "usr": "s:SS9UTF16ViewV7IndicesV5index_8offsetBySS5IndexVAH_SitF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Function",
-                  "name": "index",
-                  "printedName": "index(_:offsetBy:limitedBy:)",
-                  "declKind": "Func",
-                  "usr": "s:SS9UTF16ViewV7IndicesV5index_8offsetBy07limitedF0SS5IndexVSgAI_SiAItF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Optional",
-                      "printedName": "String.UTF16View.Indices.Index?",
-                      "usr": "s:Sq",
-                      "children": [
-                        {
-                          "kind": "TypeNameAlias",
-                          "name": "Index",
-                          "printedName": "String.UTF16View.Indices.Index",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Index",
-                              "printedName": "String.Index",
-                              "usr": "s:SS5IndexV"
-                            }
-                          ]
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "Function",
-                  "name": "distance",
-                  "printedName": "distance(from:to:)",
-                  "declKind": "Func",
-                  "usr": "s:SS9UTF16ViewV7IndicesV8distance4from2toSiSS5IndexV_AItF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeAlias",
-                  "name": "Element",
-                  "printedName": "Element",
-                  "declKind": "TypeAlias",
-                  "usr": "s:SS9UTF16ViewV7IndicesV7Elementa",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeAlias",
-                  "name": "Iterator",
-                  "printedName": "Iterator",
-                  "declKind": "TypeAlias",
-                  "usr": "s:SS9UTF16ViewV7IndicesV8Iteratora",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "IndexingIterator",
-                      "printedName": "IndexingIterator<String.UTF16View.Indices>",
-                      "usr": "s:s16IndexingIteratorV",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Indices",
-                          "printedName": "String.UTF16View.Indices",
-                          "usr": "s:SS9UTF16ViewV7IndicesV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "indices",
-              "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:SS9UTF16ViewV7indicesAB7IndicesVvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Indices",
-                  "printedName": "String.UTF16View.Indices",
-                  "usr": "s:SS9UTF16ViewV7IndicesV"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS9UTF16ViewV7indicesAB7IndicesVvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Indices",
-                      "printedName": "String.UTF16View.Indices",
-                      "usr": "s:SS9UTF16ViewV7IndicesV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SS9UTF16ViewV5index5afterSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:SS9UTF16ViewV5index6beforeSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(_:offsetBy:)",
-              "declKind": "Func",
-              "usr": "s:SS9UTF16ViewV5index_8offsetBySS5IndexVAF_SitF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(_:offsetBy:limitedBy:)",
-              "declKind": "Func",
-              "usr": "s:SS9UTF16ViewV5index_8offsetBy07limitedE0SS5IndexVSgAG_SiAGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF16View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "distance",
-              "printedName": "distance(from:to:)",
-              "declKind": "Func",
-              "usr": "s:SS9UTF16ViewV8distance4from2toSiSS5IndexV_AGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "description",
-              "printedName": "description",
-              "declKind": "Var",
-              "usr": "s:SS9UTF16ViewV11descriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS9UTF16ViewV11descriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "String",
-                      "printedName": "String",
-                      "usr": "s:SS"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "debugDescription",
-              "printedName": "debugDescription",
-              "declKind": "Var",
-              "usr": "s:SS9UTF16ViewV16debugDescriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS9UTF16ViewV16debugDescriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "String",
-                      "printedName": "String",
-                      "usr": "s:SS"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:SS9UTF16ViewV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "CodeUnit",
-                  "printedName": "UTF16.CodeUnit",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt16",
-                      "printedName": "UInt16",
-                      "usr": "s:s6UInt16V"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:SS9UTF16ViewV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<String.UTF16View>",
-                  "usr": "s:s16IndexingIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UTF16View",
-                      "printedName": "String.UTF16View",
-                      "usr": "s:SS9UTF16ViewV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "customMirror",
-              "printedName": "customMirror",
-              "declKind": "Var",
-              "usr": "s:SS9UTF16ViewV12customMirrors0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS9UTF16ViewV12customMirrors0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Mirror",
-                      "printedName": "Mirror",
-                      "usr": "s:s6MirrorV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:SS9UTF16ViewV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UTF16View",
-                  "printedName": "Substring.UTF16View",
-                  "usr": "s:Ss9UTF16ViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SS9UTF16ViewV5index5afterSS5IndexVAFSg_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF16View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(_:offsetBy:)",
-              "declKind": "Func",
-              "usr": "s:SS9UTF16ViewV5index_8offsetBySS5IndexVAFSg_SitF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF16View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "distance",
-              "printedName": "distance(from:to:)",
-              "declKind": "Func",
-              "usr": "s:SS9UTF16ViewV8distance4from2toSiSS5IndexVSg_AHtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF16View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF16View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "customPlaygroundQuickLook",
-              "printedName": "customPlaygroundQuickLook",
-              "declKind": "Var",
-              "usr": "s:SS9UTF16ViewV25customPlaygroundQuickLooks01_deF0Ovp",
-              "location": "",
-              "moduleName": "Swift",
-              "deprecated": true,
-              "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "_PlaygroundQuickLook",
-                  "printedName": "_PlaygroundQuickLook",
-                  "usr": "s:s20_PlaygroundQuickLookO"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS9UTF16ViewV25customPlaygroundQuickLooks01_deF0Ovg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "_PlaygroundQuickLook",
-                      "printedName": "_PlaygroundQuickLook",
-                      "usr": "s:s20_PlaygroundQuickLookO"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "utf16",
-          "printedName": "utf16",
-          "declKind": "Var",
-          "usr": "s:SS5utf16SS9UTF16ViewVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UTF16View",
-              "printedName": "String.UTF16View",
-              "usr": "s:SS9UTF16ViewV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS5utf16SS9UTF16ViewVvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UTF16View",
-                  "printedName": "String.UTF16View",
-                  "usr": "s:SS9UTF16ViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Setter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS5utf16SS9UTF16ViewVvs",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "UTF16View",
-                  "printedName": "String.UTF16View",
-                  "usr": "s:SS9UTF16ViewV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "UTF16Index",
-          "printedName": "UTF16Index",
-          "declKind": "TypeAlias",
-          "usr": "s:SS10UTF16Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "String.UTF16View.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeDecl",
-          "name": "UTF8View",
-          "printedName": "UTF8View",
-          "declKind": "Struct",
-          "usr": "s:SS8UTF8ViewV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "CustomStringConvertible",
-            "CustomDebugStringConvertible",
-            "Collection",
-            "Sequence",
-            "_SwiftStringView",
-            "CustomReflectable",
-            "_CustomPlaygroundQuickLookable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:SS8UTF8ViewV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "startIndex",
-              "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:SS8UTF8ViewV10startIndexSS0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS8UTF8ViewV10startIndexSS0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF8View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "endIndex",
-              "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:SS8UTF8ViewV8endIndexSS0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS8UTF8ViewV8endIndexSS0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF8View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SS8UTF8ViewV5index5afterSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inline",
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:SS8UTF8ViewV5index6beforeSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "distance",
-              "printedName": "distance(from:to:)",
-              "declKind": "Func",
-              "usr": "s:SS8UTF8ViewV8distance4from2toSiSS5IndexV_AGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "description",
-              "printedName": "description",
-              "declKind": "Var",
-              "usr": "s:SS8UTF8ViewV11descriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS8UTF8ViewV11descriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "String",
-                      "printedName": "String",
-                      "usr": "s:SS"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "debugDescription",
-              "printedName": "debugDescription",
-              "declKind": "Var",
-              "usr": "s:SS8UTF8ViewV16debugDescriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS8UTF8ViewV16debugDescriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "String",
-                      "printedName": "String",
-                      "usr": "s:SS"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:SS8UTF8ViewV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "CodeUnit",
-                  "printedName": "UTF8.CodeUnit",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt8",
-                      "printedName": "UInt8",
-                      "usr": "s:s5UInt8V"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:SS8UTF8ViewV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DefaultIndices",
-                  "printedName": "DefaultIndices<String.UTF8View>",
-                  "usr": "s:SI",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UTF8View",
-                      "printedName": "String.UTF8View",
-                      "usr": "s:SS8UTF8ViewV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeDecl",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "Struct",
-              "usr": "s:SS8UTF8ViewV8IteratorV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "IteratorProtocol"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
-              "children": [
-                {
-                  "kind": "TypeAlias",
-                  "name": "Element",
-                  "printedName": "Element",
-                  "declKind": "TypeAlias",
-                  "usr": "s:SS8UTF8ViewV8IteratorV7Elementa",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "String.UTF8View.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "UInt8",
-                          "printedName": "UInt8",
-                          "usr": "s:s5UInt8V"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "Constructor",
-                  "name": "init",
-                  "printedName": "init(_:)",
-                  "declKind": "Constructor",
-                  "usr": "s:SS8UTF8ViewV8IteratorVyAdBcfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Iterator",
-                      "printedName": "String.UTF8View.Iterator",
-                      "usr": "s:SS8UTF8ViewV8IteratorV"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UTF8View",
-                      "printedName": "String.UTF8View",
-                      "usr": "s:SS8UTF8ViewV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Function",
-                  "name": "next",
-                  "printedName": "next()",
-                  "declKind": "Func",
-                  "usr": "s:SS8UTF8ViewV8IteratorV4nexts5UInt8VSgyF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "mutating": true,
-                  "declAttributes": [
-                    "Inline",
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Optional",
-                      "printedName": "Unicode.UTF8.CodeUnit?",
-                      "usr": "s:Sq",
-                      "children": [
-                        {
-                          "kind": "TypeNameAlias",
-                          "name": "CodeUnit",
-                          "printedName": "Unicode.UTF8.CodeUnit",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt8",
-                              "printedName": "UInt8",
-                              "usr": "s:s5UInt8V"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "makeIterator",
-              "printedName": "makeIterator()",
-              "declKind": "Func",
-              "usr": "s:SS8UTF8ViewV12makeIteratorAB0D0VyF",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "String.UTF8View.Iterator",
-                  "usr": "s:SS8UTF8ViewV8IteratorV"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "count",
-              "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:SS8UTF8ViewV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS8UTF8ViewV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "customMirror",
-              "printedName": "customMirror",
-              "declKind": "Var",
-              "usr": "s:SS8UTF8ViewV12customMirrors0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS8UTF8ViewV12customMirrors0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Mirror",
-                      "printedName": "Mirror",
-                      "usr": "s:s6MirrorV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:SS8UTF8ViewV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UTF8View",
-                  "printedName": "Substring.UTF8View",
-                  "usr": "s:Ss8UTF8ViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SS8UTF8ViewV5index5afterSS5IndexVAFSg_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF8View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF8View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(_:offsetBy:)",
-              "declKind": "Func",
-              "usr": "s:SS8UTF8ViewV5index_8offsetBySS5IndexVAFSg_SitF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF8View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF8View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "distance",
-              "printedName": "distance(from:to:)",
-              "declKind": "Func",
-              "usr": "s:SS8UTF8ViewV8distance4from2toSiSS5IndexVSg_AHtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF8View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF8View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF8View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF8View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "customPlaygroundQuickLook",
-              "printedName": "customPlaygroundQuickLook",
-              "declKind": "Var",
-              "usr": "s:SS8UTF8ViewV25customPlaygroundQuickLooks01_deF0Ovp",
-              "location": "",
-              "moduleName": "Swift",
-              "deprecated": true,
-              "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "_PlaygroundQuickLook",
-                  "printedName": "_PlaygroundQuickLook",
-                  "usr": "s:s20_PlaygroundQuickLookO"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS8UTF8ViewV25customPlaygroundQuickLooks01_deF0Ovg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "_PlaygroundQuickLook",
-                      "printedName": "_PlaygroundQuickLook",
-                      "usr": "s:s20_PlaygroundQuickLookO"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "utf8",
-          "printedName": "utf8",
-          "declKind": "Var",
-          "usr": "s:SS4utf8SS8UTF8ViewVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UTF8View",
-              "printedName": "String.UTF8View",
-              "usr": "s:SS8UTF8ViewV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS4utf8SS8UTF8ViewVvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UTF8View",
-                  "printedName": "String.UTF8View",
-                  "usr": "s:SS8UTF8ViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Setter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS4utf8SS8UTF8ViewVvs",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "UTF8View",
-                  "printedName": "String.UTF8View",
-                  "usr": "s:SS8UTF8ViewV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "utf8CString",
-          "printedName": "utf8CString",
-          "declKind": "Var",
-          "usr": "s:SS11utf8CStrings15ContiguousArrayVys4Int8VGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ContiguousArray",
-              "printedName": "ContiguousArray<CChar>",
-              "usr": "s:s15ContiguousArrayV",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "CChar",
-                  "printedName": "CChar",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int8",
-                      "printedName": "Int8",
-                      "usr": "s:s4Int8V"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS11utf8CStrings15ContiguousArrayVys4Int8VGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "ContiguousArray",
-                  "printedName": "ContiguousArray<CChar>",
-                  "usr": "s:s15ContiguousArrayV",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "CChar",
-                      "printedName": "CChar",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Int8",
-                          "printedName": "Int8",
-                          "usr": "s:s4Int8V"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "UTF8Index",
-          "printedName": "UTF8Index",
-          "declKind": "TypeAlias",
-          "usr": "s:SS9UTF8Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "String.UTF8View.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSSscfc",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSSgSs8UTF8ViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "String?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UTF8View",
-              "printedName": "Substring.UTF8View",
-              "usr": "s:Ss8UTF8ViewV"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSSgSs9UTF16ViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "String?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UTF16View",
-              "printedName": "Substring.UTF16View",
-              "usr": "s:Ss9UTF16ViewV"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSSs17UnicodeScalarViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnicodeScalarView",
-              "printedName": "Substring.UnicodeScalarView",
-              "usr": "s:Ss17UnicodeScalarViewV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "CharacterView",
-          "printedName": "CharacterView",
-          "declKind": "TypeAlias",
-          "usr": "s:SS13CharacterViewa",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "characters",
-          "printedName": "characters",
-          "declKind": "Var",
-          "usr": "s:SS10charactersSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS10charactersSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            },
-            {
-              "kind": "Setter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS10charactersSSvs",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withMutableCharacters",
-          "printedName": "withMutableCharacters(_:)",
-          "declKind": "Func",
-          "usr": "s:SS21withMutableCharactersyxxSSzXElF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<R>",
-          "deprecated": true,
-          "mutating": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(inout String) -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(inout String)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "InOut",
-                      "printedName": "inout String"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSSgSS9UTF16ViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "String?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UTF16View",
-              "printedName": "String.UTF16View",
-              "usr": "s:SS9UTF16ViewV"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSSgSS8UTF8ViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "String?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UTF8View",
-              "printedName": "String.UTF8View",
-              "usr": "s:SS8UTF8ViewV"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:obsoletedInSwift4:)",
-          "declKind": "Constructor",
-          "usr": "s:SS_17obsoletedInSwift4SSSgSS_yttcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "String?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()",
-              "hasDefaultArg": true
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "popFirst",
-          "printedName": "popFirst()",
-          "declKind": "Func",
-          "usr": "s:SS8popFirstSJSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "mutating": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "String.Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "String.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Character",
-                      "printedName": "Character",
-                      "usr": "s:SJ"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(describing:)",
-          "declKind": "Constructor",
-          "usr": "s:SS10describingSSx_tclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Subject>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Subject"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(reflecting:)",
-          "declKind": "Constructor",
-          "usr": "s:SS10reflectingSSx_tclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Subject>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Subject"
-            }
           ]
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "StringProtocol",
-      "printedName": "StringProtocol",
+      ],
       "declKind": "Protocol",
       "usr": "s:Sy",
-      "location": "",
       "moduleName": "Swift",
-      "genericSig": "<Self : BidirectionalCollection, Self : Comparable, Self : ExpressibleByStringLiteral, Self : Hashable, Self : LosslessStringConvertible, Self : TextOutputStream, Self : TextOutputStreamable, Self.Element == Character, Self.SubSequence : StringProtocol, Self.UTF16View : BidirectionalCollection, Self.UTF8View : Collection, Self.UnicodeScalarView : BidirectionalCollection, Self.UTF16View.Element == UInt16, Self.UTF8View.Element == UInt8, Self.UnicodeScalarView.Element == Unicode.Scalar>",
+      "genericSig": "<τ_0_0 : BidirectionalCollection, τ_0_0 : Comparable, τ_0_0 : ExpressibleByStringLiteral, τ_0_0 : Hashable, τ_0_0 : LosslessStringConvertible, τ_0_0 : TextOutputStream, τ_0_0 : TextOutputStreamable, τ_0_0.Element == Character, τ_0_0.SubSequence : StringProtocol, τ_0_0.UTF16View : BidirectionalCollection, τ_0_0.UTF8View : Collection, τ_0_0.UnicodeScalarView : BidirectionalCollection, τ_0_0.UTF16View.Element == UInt16, τ_0_0.UTF8View.Element == UInt8, τ_0_0.UnicodeScalarView.Element == Unicode.Scalar>",
       "conformingProtocols": [
         "BidirectionalCollection",
         "TextOutputStream",
@@ -93958,451 +102028,387 @@
         "Equatable",
         "Sequence",
         "ExpressibleByUnicodeScalarLiteral"
-      ],
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Substring",
+      "printedName": "Substring",
       "children": [
         {
           "kind": "Var",
-          "name": "utf8",
-          "printedName": "utf8",
-          "declKind": "Var",
-          "usr": "s:Sy4utf88UTF8ViewQzvp",
-          "location": "",
-          "moduleName": "Swift",
+          "name": "_slice",
+          "printedName": "_slice",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.UTF8View"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sy4utf88UTF8ViewQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : StringProtocol>",
+              "name": "Slice",
+              "printedName": "Slice<String>",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.UTF8View"
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
                 }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "utf16",
-          "printedName": "utf16",
-          "declKind": "Var",
-          "usr": "s:Sy5utf169UTF16ViewQzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.UTF16View"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sy5utf169UTF16ViewQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : StringProtocol>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.UTF16View"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "unicodeScalars",
-          "printedName": "unicodeScalars",
-          "declKind": "Var",
-          "usr": "s:Sy14unicodeScalars17UnicodeScalarViewQzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.UnicodeScalarView"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sy14unicodeScalars17UnicodeScalarViewQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : StringProtocol>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.UnicodeScalarView"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "hasPrefix",
-          "printedName": "hasPrefix(_:)",
-          "declKind": "Func",
-          "usr": "s:Sy9hasPrefixySbSSF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "hasSuffix",
-          "printedName": "hasSuffix(_:)",
-          "declKind": "Func",
-          "usr": "s:Sy9hasSuffixySbSSF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "lowercased",
-          "printedName": "lowercased()",
-          "declKind": "Func",
-          "usr": "s:Sy10lowercasedSSyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "uppercased",
-          "printedName": "uppercased()",
-          "declKind": "Func",
-          "usr": "s:Sy10uppercasedSSyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(decoding:as:)",
-          "declKind": "Constructor",
-          "usr": "s:Sy8decoding2asxqd___qd_0_mtcSlRd__s16_UnicodeEncodingRd_0_8CodeUnitQyd_0_7ElementRtd__r0_lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, C, Encoding where Self : StringProtocol, C : Collection, Encoding : _UnicodeEncoding, C.Element == Encoding.CodeUnit>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "C"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "Encoding.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Encoding"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(cString:)",
-          "declKind": "Constructor",
-          "usr": "s:Sy7cStringxSPys4Int8VG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafePointer",
-              "printedName": "UnsafePointer<CChar>",
-              "usr": "s:SP",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "CChar",
-                  "printedName": "CChar",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int8",
-                      "printedName": "Int8",
-                      "usr": "s:s4Int8V"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(decodingCString:as:)",
-          "declKind": "Constructor",
-          "usr": "s:Sy15decodingCString2asxSPy8CodeUnitQyd__G_qd__mtcs16_UnicodeEncodingRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Encoding where Self : StringProtocol, Encoding : _UnicodeEncoding>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafePointer",
-              "printedName": "UnsafePointer<Encoding.CodeUnit>",
-              "usr": "s:SP",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Encoding.CodeUnit"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "Encoding.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Encoding"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withCString",
-          "printedName": "withCString(_:)",
-          "declKind": "Func",
-          "usr": "s:Sy11withCStringyqd__qd__SPys4Int8VGKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Result where Self : StringProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Result"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafePointer<CChar>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
               ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Result"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafePointer<CChar>)",
-                  "usr": "s:SP",
+                  "name": "Slice",
+                  "printedName": "Slice<String>",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "UnsafePointer",
-                      "printedName": "UnsafePointer<CChar>",
-                      "usr": "s:SP",
-                      "children": [
-                        {
-                          "kind": "TypeNameAlias",
-                          "name": "CChar",
-                          "printedName": "CChar",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Int8",
-                              "printedName": "Int8",
-                              "usr": "s:s4Int8V"
-                            }
-                          ]
-                        }
-                      ]
+                      "name": "String",
+                      "printedName": "String",
+                      "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "usr": "s:s5SliceV"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss6_slices5SliceVySSGvg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss6_slices5SliceVySSGvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
         },
         {
-          "kind": "Function",
-          "name": "withCString",
-          "printedName": "withCString(encodedAs:_:)",
-          "declKind": "Func",
-          "usr": "s:Sy11withCString9encodedAs_qd__qd_0_m_qd__SPy8CodeUnitQyd_0_GKXEtKs16_UnicodeEncodingRd_0_r0_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Result, Encoding where Self : StringProtocol, Encoding : _UnicodeEncoding>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init()",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Result"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "Encoding.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Encoding"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafePointer<Encoding.CodeUnit>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Result"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafePointer<Encoding.CodeUnit>)",
-                  "usr": "s:SP",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafePointer",
-                      "printedName": "UnsafePointer<Encoding.CodeUnit>",
-                      "usr": "s:SP",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "DependentMember",
-                          "printedName": "Encoding.CodeUnit"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "hash",
-          "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SysE4hash4intoys6HasherVz_tF",
-          "location": "",
+          ],
+          "declKind": "Constructor",
+          "usr": "s:S2sycfc",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
           "declAttributes": [
             "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "_StringGuts",
+              "printedName": "_StringGuts",
+              "usr": "s:s11_StringGutsV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
           ],
+          "declKind": "Constructor",
+          "usr": "s:SsySss11_StringGutsV_SnySiGtcfc",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss10startIndexSS0B0Vvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss10startIndexSS0B0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss8endIndexSS0B0Vvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss8endIndexSS0B0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss5index5afterSS5IndexVAD_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss5index6beforeSS5IndexVAD_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss5index_8offsetBySS5IndexVAD_SitF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:limitedBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<String.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss5index_8offsetBy07limitedC0SS5IndexVSgAE_SiAEtF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(from:to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss8distance4from2toSiSS5IndexV_AEtF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SsySJSS5IndexVcip",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "replaceSubrange",
+          "printedName": "replaceSubrange(_:with:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -94411,137 +102417,2559 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Hasher",
-              "printedName": "Hasher",
-              "usr": "s:s6HasherV"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "hasPrefix",
-          "printedName": "hasPrefix(_:)",
-          "declKind": "Func",
-          "usr": "s:SysE9hasPrefixySbqd__SyRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Prefix where Self : StringProtocol, Prefix : StringProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
+              "name": "Range",
+              "printedName": "Range<String.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Prefix"
+              "printedName": "τ_0_0"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "hasSuffix",
-          "printedName": "hasSuffix(_:)",
+          ],
           "declKind": "Func",
-          "usr": "s:SysE9hasSuffixySbqd__SyRd__lF",
-          "location": "",
+          "usr": "s:Ss15replaceSubrange_4withySnySS5IndexVG_xtSlRzSJ7ElementRtzlF",
           "moduleName": "Swift",
-          "genericSig": "<Self, Suffix where Self : StringProtocol, Suffix : StringProtocol>",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element == Character>",
           "declAttributes": [
             "Inlinable"
           ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "replaceSubrange",
+          "printedName": "replaceSubrange(_:with:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<String.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss15replaceSubrange_4withySnySS5IndexVG_SstF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(decoding:as:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Suffix"
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_0_1.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Ss8decoding2asSsx_q_mtcSlRzs16_UnicodeEncodingR_8CodeUnitQy_7ElementRtzr0_lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Collection, τ_0_1 : _UnicodeEncoding, τ_0_0.Element == τ_0_1.CodeUnit>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "TypeAlias",
-          "name": "UTF8Index",
-          "printedName": "UTF8Index",
-          "declKind": "TypeAlias",
-          "usr": "s:SysE9UTF8Indexa",
-          "location": "",
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(cString:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafePointer",
+              "printedName": "UnsafePointer<Int8>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int8",
+                  "printedName": "Int8",
+                  "usr": "s:s4Int8V"
+                }
+              ],
+              "usr": "s:SP"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Ss7cStringSsSPys4Int8VG_tcfc",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(decodingCString:as:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafePointer",
+              "printedName": "UnsafePointer<τ_0_0.CodeUnit>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.CodeUnit"
+                }
+              ],
+              "usr": "s:SP"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_0_0.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Ss15decodingCString2asSsSPy8CodeUnitQzG_xmtcs16_UnicodeEncodingRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : _UnicodeEncoding>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "withCString",
+          "printedName": "withCString(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafePointer<Int8>) throws -> τ_0_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafePointer",
+                  "printedName": "UnsafePointer<Int8>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int8",
+                      "printedName": "Int8",
+                      "usr": "s:s4Int8V"
+                    }
+                  ],
+                  "usr": "s:SP"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss11withCStringyxxSPys4Int8VGKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "withCString",
+          "printedName": "withCString(encodedAs:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_0_1.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ]
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafePointer<τ_0_1.CodeUnit>) throws -> τ_0_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafePointer",
+                  "printedName": "UnsafePointer<τ_0_1.CodeUnit>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_1.CodeUnit"
+                    }
+                  ],
+                  "usr": "s:SP"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss11withCString9encodedAs_xq_m_xSPy8CodeUnitQy_GKXEtKs16_UnicodeEncodingR_r0_lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_1 : _UnicodeEncoding>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Var",
+          "name": "hashValue",
+          "printedName": "hashValue",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Var",
+          "name": "customMirror",
+          "printedName": "customMirror",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Mirror",
+              "printedName": "Mirror",
+              "usr": "s:s6MirrorV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss12customMirrors0B0Vvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss12customMirrors0B0Vvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "description",
+          "printedName": "description",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss11descriptionSSvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss16debugDescriptionSSvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SsySsSScfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "UTF8View",
+          "printedName": "UTF8View",
+          "children": [
+            {
+              "kind": "Var",
+              "name": "_slice",
+              "printedName": "_slice",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Slice",
+                  "printedName": "Slice<String.UTF8View>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UTF8View",
+                      "printedName": "String.UTF8View",
+                      "usr": "s:SS8UTF8ViewV"
+                    }
+                  ],
+                  "usr": "s:s5SliceV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Slice",
+                      "printedName": "Slice<String.UTF8View>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UTF8View",
+                          "printedName": "String.UTF8View",
+                          "usr": "s:SS8UTF8ViewV"
+                        }
+                      ],
+                      "usr": "s:s5SliceV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss8UTF8ViewV6_slices5SliceVySSAAVGvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss8UTF8ViewV6_slices5SliceVySSAAVGvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "startIndex",
+              "printedName": "startIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss8UTF8ViewV10startIndexSS0D0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss8UTF8ViewV10startIndexSS0D0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "endIndex",
+              "printedName": "endIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss8UTF8ViewV8endIndexSS0D0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss8UTF8ViewV8endIndexSS0D0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt8",
+                  "printedName": "UInt8",
+                  "usr": "s:s5UInt8V"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:Ss8UTF8ViewVys5UInt8VSS5IndexVcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "indices",
+              "printedName": "indices",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DefaultIndices",
+                  "printedName": "DefaultIndices<String.UTF8View>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UTF8View",
+                      "printedName": "String.UTF8View",
+                      "usr": "s:SS8UTF8ViewV"
+                    }
+                  ],
+                  "usr": "s:SI"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DefaultIndices",
+                      "printedName": "DefaultIndices<String.UTF8View>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UTF8View",
+                          "printedName": "String.UTF8View",
+                          "usr": "s:SS8UTF8ViewV"
+                        }
+                      ],
+                      "usr": "s:SI"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss8UTF8ViewV7indicesSIySSAAVGvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss8UTF8ViewV7indicesSIySSAAVGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss8UTF8ViewV5index5afterSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "formIndex",
+              "printedName": "formIndex(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss8UTF8ViewV9formIndex5afterySS0D0Vz_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(_:offsetBy:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss8UTF8ViewV5index_8offsetBySS5IndexVAF_SitF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(_:offsetBy:limitedBy:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss8UTF8ViewV5index_8offsetBy07limitedE0SS5IndexVSgAG_SiAGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "distance",
+              "printedName": "distance(from:to:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss8UTF8ViewV8distance4from2toSiSS5IndexV_AGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(before:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss8UTF8ViewV5index6beforeSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "formIndex",
+              "printedName": "formIndex(before:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss8UTF8ViewV9formIndex6beforeySS0D0Vz_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF8View",
+                  "printedName": "Substring.UTF8View",
+                  "usr": "s:Ss8UTF8ViewV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:Ss8UTF8ViewVyABSnySS5IndexVGcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:Ss8UTF8ViewV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "utf8",
+          "printedName": "utf8",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UTF8View",
+              "printedName": "Substring.UTF8View",
+              "usr": "s:Ss8UTF8ViewV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF8View",
+                  "printedName": "Substring.UTF8View",
+                  "usr": "s:Ss8UTF8ViewV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss4utf8Ss8UTF8ViewVvg",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF8View",
+                  "printedName": "Substring.UTF8View",
+                  "usr": "s:Ss8UTF8ViewV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss4utf8Ss8UTF8ViewVvs",
+              "moduleName": "Swift",
+              "mutating": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss4utf8Ss8UTF8ViewVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UTF8View",
+              "printedName": "Substring.UTF8View",
+              "usr": "s:Ss8UTF8ViewV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SsyS2s8UTF8ViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "UTF16View",
+          "printedName": "UTF16View",
+          "children": [
+            {
+              "kind": "Var",
+              "name": "_slice",
+              "printedName": "_slice",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Slice",
+                  "printedName": "Slice<String.UTF16View>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UTF16View",
+                      "printedName": "String.UTF16View",
+                      "usr": "s:SS9UTF16ViewV"
+                    }
+                  ],
+                  "usr": "s:s5SliceV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Slice",
+                      "printedName": "Slice<String.UTF16View>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UTF16View",
+                          "printedName": "String.UTF16View",
+                          "usr": "s:SS9UTF16ViewV"
+                        }
+                      ],
+                      "usr": "s:s5SliceV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss9UTF16ViewV6_slices5SliceVySSAAVGvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss9UTF16ViewV6_slices5SliceVySSAAVGvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "startIndex",
+              "printedName": "startIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss9UTF16ViewV10startIndexSS0D0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss9UTF16ViewV10startIndexSS0D0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "endIndex",
+              "printedName": "endIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss9UTF16ViewV8endIndexSS0D0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss9UTF16ViewV8endIndexSS0D0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt16",
+                  "printedName": "UInt16",
+                  "usr": "s:s6UInt16V"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:Ss9UTF16ViewVys6UInt16VSS5IndexVcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "indices",
+              "printedName": "indices",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Indices",
+                  "printedName": "String.UTF16View.Indices",
+                  "usr": "s:SS9UTF16ViewV7IndicesV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Indices",
+                      "printedName": "String.UTF16View.Indices",
+                      "usr": "s:SS9UTF16ViewV7IndicesV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss9UTF16ViewV7indicesSSAAV7IndicesVvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss9UTF16ViewV7indicesSSAAV7IndicesVvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss9UTF16ViewV5index5afterSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "formIndex",
+              "printedName": "formIndex(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss9UTF16ViewV9formIndex5afterySS0D0Vz_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(_:offsetBy:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss9UTF16ViewV5index_8offsetBySS5IndexVAF_SitF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(_:offsetBy:limitedBy:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss9UTF16ViewV5index_8offsetBy07limitedE0SS5IndexVSgAG_SiAGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "distance",
+              "printedName": "distance(from:to:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss9UTF16ViewV8distance4from2toSiSS5IndexV_AGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(before:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss9UTF16ViewV5index6beforeSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "formIndex",
+              "printedName": "formIndex(before:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss9UTF16ViewV9formIndex6beforeySS0D0Vz_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF16View",
+                  "printedName": "Substring.UTF16View",
+                  "usr": "s:Ss9UTF16ViewV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:Ss9UTF16ViewVyABSnySS5IndexVGcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:Ss9UTF16ViewV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "utf16",
+          "printedName": "utf16",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UTF16View",
+              "printedName": "Substring.UTF16View",
+              "usr": "s:Ss9UTF16ViewV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF16View",
+                  "printedName": "Substring.UTF16View",
+                  "usr": "s:Ss9UTF16ViewV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss5utf16Ss9UTF16ViewVvg",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF16View",
+                  "printedName": "Substring.UTF16View",
+                  "usr": "s:Ss9UTF16ViewV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss5utf16Ss9UTF16ViewVvs",
+              "moduleName": "Swift",
+              "mutating": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss5utf16Ss9UTF16ViewVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UTF16View",
+              "printedName": "Substring.UTF16View",
+              "usr": "s:Ss9UTF16ViewV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SsyS2s9UTF16ViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "UnicodeScalarView",
+          "printedName": "UnicodeScalarView",
+          "children": [
+            {
+              "kind": "Var",
+              "name": "_slice",
+              "printedName": "_slice",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Slice",
+                  "printedName": "Slice<String.UnicodeScalarView>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnicodeScalarView",
+                      "printedName": "String.UnicodeScalarView",
+                      "usr": "s:SS17UnicodeScalarViewV"
+                    }
+                  ],
+                  "usr": "s:s5SliceV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Slice",
+                      "printedName": "Slice<String.UnicodeScalarView>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UnicodeScalarView",
+                          "printedName": "String.UnicodeScalarView",
+                          "usr": "s:SS17UnicodeScalarViewV"
+                        }
+                      ],
+                      "usr": "s:s5SliceV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss17UnicodeScalarViewV6_slices5SliceVySSAAVGvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss17UnicodeScalarViewV6_slices5SliceVySSAAVGvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "startIndex",
+              "printedName": "startIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss17UnicodeScalarViewV10startIndexSS0E0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss17UnicodeScalarViewV10startIndexSS0E0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "endIndex",
+              "printedName": "endIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss17UnicodeScalarViewV8endIndexSS0E0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss17UnicodeScalarViewV8endIndexSS0E0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Scalar",
+                  "printedName": "Unicode.Scalar",
+                  "usr": "s:s7UnicodeO6ScalarV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:Ss17UnicodeScalarViewVys0A0O0B0VSS5IndexVcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "indices",
+              "printedName": "indices",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DefaultIndices",
+                  "printedName": "DefaultIndices<String.UnicodeScalarView>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnicodeScalarView",
+                      "printedName": "String.UnicodeScalarView",
+                      "usr": "s:SS17UnicodeScalarViewV"
+                    }
+                  ],
+                  "usr": "s:SI"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DefaultIndices",
+                      "printedName": "DefaultIndices<String.UnicodeScalarView>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UnicodeScalarView",
+                          "printedName": "String.UnicodeScalarView",
+                          "usr": "s:SS17UnicodeScalarViewV"
+                        }
+                      ],
+                      "usr": "s:SI"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss17UnicodeScalarViewV7indicesSIySSAAVGvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss17UnicodeScalarViewV7indicesSIySSAAVGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss17UnicodeScalarViewV5index5afterSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "formIndex",
+              "printedName": "formIndex(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss17UnicodeScalarViewV9formIndex5afterySS0E0Vz_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(_:offsetBy:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss17UnicodeScalarViewV5index_8offsetBySS5IndexVAF_SitF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(_:offsetBy:limitedBy:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss17UnicodeScalarViewV5index_8offsetBy07limitedF0SS5IndexVSgAG_SiAGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "distance",
+              "printedName": "distance(from:to:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss17UnicodeScalarViewV8distance4from2toSiSS5IndexV_AGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(before:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss17UnicodeScalarViewV5index6beforeSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "formIndex",
+              "printedName": "formIndex(before:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss17UnicodeScalarViewV9formIndex6beforeySS0E0Vz_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnicodeScalarView",
+                  "printedName": "Substring.UnicodeScalarView",
+                  "usr": "s:Ss17UnicodeScalarViewV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:Ss17UnicodeScalarViewVyABSnySS5IndexVGcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Constructor",
+              "name": "init",
+              "printedName": "init()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnicodeScalarView",
+                  "printedName": "Substring.UnicodeScalarView",
+                  "usr": "s:Ss17UnicodeScalarViewV"
+                }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:Ss17UnicodeScalarViewVABycfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "replaceSubrange",
+              "printedName": "replaceSubrange(_:with:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<String.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss17UnicodeScalarViewV15replaceSubrange_4withySnySS5IndexVG_xtSlRzs0A0O0B0V7ElementRtzlF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element == Unicode.Scalar>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:Ss17UnicodeScalarViewV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence",
+            "RangeReplaceableCollection"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "unicodeScalars",
+          "printedName": "unicodeScalars",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnicodeScalarView",
+              "printedName": "Substring.UnicodeScalarView",
+              "usr": "s:Ss17UnicodeScalarViewV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnicodeScalarView",
+                  "printedName": "Substring.UnicodeScalarView",
+                  "usr": "s:Ss17UnicodeScalarViewV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss14unicodeScalarsSs17UnicodeScalarViewVvg",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnicodeScalarView",
+                  "printedName": "Substring.UnicodeScalarView",
+                  "usr": "s:Ss17UnicodeScalarViewV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss14unicodeScalarsSs17UnicodeScalarViewVvs",
+              "moduleName": "Swift",
+              "mutating": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss14unicodeScalarsSs17UnicodeScalarViewVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnicodeScalarView",
+              "printedName": "Substring.UnicodeScalarView",
+              "usr": "s:Ss17UnicodeScalarViewV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SsyS2s17UnicodeScalarViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SsySsxcSTRzSJ7ElementRtzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element == Character>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "append",
+          "printedName": "append(contentsOf:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss6append10contentsOfyx_tSTRzSJ7ElementRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence, τ_0_0.Element == Character>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "lowercased",
+          "printedName": "lowercased()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss10lowercasedSSyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "uppercased",
+          "printedName": "uppercased()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss10uppercasedSSyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "filter",
+          "printedName": "filter(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(Character) throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Character",
+                  "printedName": "Character",
+                  "usr": "s:SJ"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss6filterySSSbSJKXEKF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "write",
+          "printedName": "write(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss5writeyySSF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "write",
+          "printedName": "write(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss5write2toyxz_ts16TextOutputStreamRzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : TextOutputStream>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(unicodeScalarLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Ss20unicodeScalarLiteralSsSS_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(extendedGraphemeClusterLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Ss30extendedGraphemeClusterLiteralSsSS_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(stringLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Ss13stringLiteralSsSS_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<String.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SsySsSnySS5IndexVGcip",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Available",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "characters",
+          "printedName": "characters",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Substring",
+                  "printedName": "Substring",
+                  "usr": "s:Ss"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss10charactersSsvg",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Substring",
+                  "printedName": "Substring",
+                  "usr": "s:Ss"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss10charactersSsvs",
+              "moduleName": "Swift",
+              "mutating": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss10charactersSsvp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "withMutableCharacters",
+          "printedName": "withMutableCharacters(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(inout Substring) -> τ_0_0",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "InOut",
+                  "printedName": "inout Substring"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss21withMutableCharactersyxxSszXElF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
           "deprecated": true,
           "declAttributes": [
             "Available"
           ],
+          "mutating": true
+        },
+        {
+          "kind": "Var",
+          "name": "customPlaygroundQuickLook",
+          "printedName": "customPlaygroundQuickLook",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.UTF8View.Index"
+              "name": "_PlaygroundQuickLook",
+              "printedName": "_PlaygroundQuickLook",
+              "usr": "s:s20_PlaygroundQuickLookO"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_PlaygroundQuickLook",
+                  "printedName": "_PlaygroundQuickLook",
+                  "usr": "s:s20_PlaygroundQuickLookO"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "UTF16Index",
-          "printedName": "UTF16Index",
-          "declKind": "TypeAlias",
-          "usr": "s:SysE10UTF16Indexa",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss25customPlaygroundQuickLooks01_bcD0Ovp",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
           "deprecated": true,
           "declAttributes": [
             "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.UTF16View.Index"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "UnicodeScalarIndex",
-          "printedName": "UnicodeScalarIndex",
-          "declKind": "TypeAlias",
-          "usr": "s:SysE18UnicodeScalarIndexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.UnicodeScalarView.Index"
-            }
           ]
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "Substring",
-      "printedName": "Substring",
+      ],
       "declKind": "Struct",
       "usr": "s:Ss",
-      "location": "",
       "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "StringProtocol",
         "BidirectionalCollection",
@@ -94562,3708 +104990,74 @@
         "ExpressibleByExtendedGraphemeClusterLiteral",
         "ExpressibleByStringLiteral",
         "_CustomPlaygroundQuickLookable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "String.Index",
-              "usr": "s:SS5IndexV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:S2sycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:_:)",
-          "declKind": "Constructor",
-          "usr": "s:SsySss11_StringGutsV_SnySiGtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "_StringGuts",
-              "printedName": "_StringGuts",
-              "usr": "s:s11_StringGutsV"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Int>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:Ss10startIndexSS0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Substring.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss10startIndexSS0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:Ss8endIndexSS0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Substring.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss8endIndexSS0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:Ss5index5afterSS5IndexVAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Substring.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Substring.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:Ss5index6beforeSS5IndexVAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Substring.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Substring.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:Ss5index_8offsetBySS5IndexVAD_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Substring.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Substring.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:Ss5index_8offsetBy07limitedC0SS5IndexVSgAE_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Substring.Index?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Substring.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Substring.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:Ss8distance4from2toSiSS5IndexV_AEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Substring.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "Substring.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "String.Index",
-                  "usr": "s:SS5IndexV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "replaceSubrange",
-          "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:Ss15replaceSubrange_4withySnySS5IndexVG_xtSlRzSJ7ElementRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<C where C : Collection, C.Element == Character>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Substring.Index>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "C"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "replaceSubrange",
-          "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:Ss15replaceSubrange_4withySnySS5IndexVG_SstF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Substring.Index>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(decoding:as:)",
-          "declKind": "Constructor",
-          "usr": "s:Ss8decoding2asSsx_q_mtcSlRzs16_UnicodeEncodingR_8CodeUnitQy_7ElementRtzr0_lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<C, Encoding where C : Collection, Encoding : _UnicodeEncoding, C.Element == Encoding.CodeUnit>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "C"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "Encoding.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Encoding"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(cString:)",
-          "declKind": "Constructor",
-          "usr": "s:Ss7cStringSsSPys4Int8VG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafePointer",
-              "printedName": "UnsafePointer<CChar>",
-              "usr": "s:SP",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "CChar",
-                  "printedName": "CChar",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int8",
-                      "printedName": "Int8",
-                      "usr": "s:s4Int8V"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(decodingCString:as:)",
-          "declKind": "Constructor",
-          "usr": "s:Ss15decodingCString2asSsSPy8CodeUnitQzG_xmtcs16_UnicodeEncodingRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Encoding where Encoding : _UnicodeEncoding>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafePointer",
-              "printedName": "UnsafePointer<Encoding.CodeUnit>",
-              "usr": "s:SP",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Encoding.CodeUnit"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "Encoding.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Encoding"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withCString",
-          "printedName": "withCString(_:)",
-          "declKind": "Func",
-          "usr": "s:Ss11withCStringyxxSPys4Int8VGKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Result>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Result"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafePointer<CChar>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Result"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafePointer<CChar>)",
-                  "usr": "s:SP",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafePointer",
-                      "printedName": "UnsafePointer<CChar>",
-                      "usr": "s:SP",
-                      "children": [
-                        {
-                          "kind": "TypeNameAlias",
-                          "name": "CChar",
-                          "printedName": "CChar",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Int8",
-                              "printedName": "Int8",
-                              "usr": "s:s4Int8V"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withCString",
-          "printedName": "withCString(encodedAs:_:)",
-          "declKind": "Func",
-          "usr": "s:Ss11withCString9encodedAs_xq_m_xSPy8CodeUnitQy_GKXEtKs16_UnicodeEncodingR_r0_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Result, TargetEncoding where TargetEncoding : _UnicodeEncoding>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Result"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "TargetEncoding.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "TargetEncoding"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafePointer<TargetEncoding.CodeUnit>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Result"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafePointer<TargetEncoding.CodeUnit>)",
-                  "usr": "s:SP",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafePointer",
-                      "printedName": "UnsafePointer<TargetEncoding.CodeUnit>",
-                      "usr": "s:SP",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "DependentMember",
-                          "printedName": "TargetEncoding.CodeUnit"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "IndexingIterator",
-              "printedName": "IndexingIterator<Substring>",
-              "usr": "s:s16IndexingIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Substring",
-                  "printedName": "Substring",
-                  "usr": "s:Ss"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DefaultIndices",
-              "printedName": "DefaultIndices<Substring>",
-              "usr": "s:SI",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Substring",
-                  "printedName": "Substring",
-                  "usr": "s:Ss"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "hashValue",
-          "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Ss9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Ss12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "description",
-          "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:Ss11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "debugDescription",
-          "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Ss16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SsySsSScfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "TypeDecl",
-          "name": "UTF8View",
-          "printedName": "UTF8View",
-          "declKind": "Struct",
-          "usr": "s:Ss8UTF8ViewV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss8UTF8ViewV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss8UTF8ViewV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "String.UTF8View.Indices",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DefaultIndices",
-                      "printedName": "DefaultIndices<String.UTF8View>",
-                      "usr": "s:SI",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "UTF8View",
-                          "printedName": "String.UTF8View",
-                          "usr": "s:SS8UTF8ViewV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss8UTF8ViewV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "String.UTF8View.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt8",
-                      "printedName": "UInt8",
-                      "usr": "s:s5UInt8V"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss8UTF8ViewV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UTF8View",
-                  "printedName": "Substring.UTF8View",
-                  "usr": "s:Ss8UTF8ViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "startIndex",
-              "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:Ss8UTF8ViewV10startIndexSS0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss8UTF8ViewV10startIndexSS0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "Substring.UTF8View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "endIndex",
-              "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:Ss8UTF8ViewV8endIndexSS0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss8UTF8ViewV8endIndexSS0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "Substring.UTF8View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "indices",
-              "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:Ss8UTF8ViewV7indicesSIySSAAVGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "Substring.UTF8View.Indices",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DefaultIndices",
-                      "printedName": "DefaultIndices<String.UTF8View>",
-                      "usr": "s:SI",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "UTF8View",
-                          "printedName": "String.UTF8View",
-                          "usr": "s:SS8UTF8ViewV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss8UTF8ViewV7indicesSIySSAAVGvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Indices",
-                      "printedName": "Substring.UTF8View.Indices",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "DefaultIndices",
-                          "printedName": "DefaultIndices<String.UTF8View>",
-                          "usr": "s:SI",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UTF8View",
-                              "printedName": "String.UTF8View",
-                              "usr": "s:SS8UTF8ViewV"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:Ss8UTF8ViewV5index5afterSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "formIndex",
-              "printedName": "formIndex(after:)",
-              "declKind": "Func",
-              "usr": "s:Ss8UTF8ViewV9formIndex5afterySS0D0Vz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(_:offsetBy:)",
-              "declKind": "Func",
-              "usr": "s:Ss8UTF8ViewV5index_8offsetBySS5IndexVAF_SitF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(_:offsetBy:limitedBy:)",
-              "declKind": "Func",
-              "usr": "s:Ss8UTF8ViewV5index_8offsetBy07limitedE0SS5IndexVSgAG_SiAGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "Substring.UTF8View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "Substring.UTF8View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "distance",
-              "printedName": "distance(from:to:)",
-              "declKind": "Func",
-              "usr": "s:Ss8UTF8ViewV8distance4from2toSiSS5IndexV_AGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:Ss8UTF8ViewV5index6beforeSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "formIndex",
-              "printedName": "formIndex(before:)",
-              "declKind": "Func",
-              "usr": "s:Ss8UTF8ViewV9formIndex6beforeySS0D0Vz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss8UTF8ViewV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<Substring.UTF8View>",
-                  "usr": "s:s16IndexingIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UTF8View",
-                      "printedName": "Substring.UTF8View",
-                      "usr": "s:Ss8UTF8ViewV"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "utf8",
-          "printedName": "utf8",
-          "declKind": "Var",
-          "usr": "s:Ss4utf8Ss8UTF8ViewVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UTF8View",
-              "printedName": "Substring.UTF8View",
-              "usr": "s:Ss8UTF8ViewV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss4utf8Ss8UTF8ViewVvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UTF8View",
-                  "printedName": "Substring.UTF8View",
-                  "usr": "s:Ss8UTF8ViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Setter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss4utf8Ss8UTF8ViewVvs",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "UTF8View",
-                  "printedName": "Substring.UTF8View",
-                  "usr": "s:Ss8UTF8ViewV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SsyS2s8UTF8ViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UTF8View",
-              "printedName": "Substring.UTF8View",
-              "usr": "s:Ss8UTF8ViewV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeDecl",
-          "name": "UTF16View",
-          "printedName": "UTF16View",
-          "declKind": "Struct",
-          "usr": "s:Ss9UTF16ViewV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss9UTF16ViewV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss9UTF16ViewV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Indices",
-                  "printedName": "String.UTF16View.Indices",
-                  "usr": "s:SS9UTF16ViewV7IndicesV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss9UTF16ViewV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "String.UTF16View.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt16",
-                      "printedName": "UInt16",
-                      "usr": "s:s6UInt16V"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss9UTF16ViewV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UTF16View",
-                  "printedName": "Substring.UTF16View",
-                  "usr": "s:Ss9UTF16ViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "startIndex",
-              "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:Ss9UTF16ViewV10startIndexSS0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss9UTF16ViewV10startIndexSS0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "Substring.UTF16View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "endIndex",
-              "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:Ss9UTF16ViewV8endIndexSS0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss9UTF16ViewV8endIndexSS0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "Substring.UTF16View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "indices",
-              "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:Ss9UTF16ViewV7indicesSSAAV7IndicesVvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "Substring.UTF16View.Indices",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Indices",
-                      "printedName": "String.UTF16View.Indices",
-                      "usr": "s:SS9UTF16ViewV7IndicesV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss9UTF16ViewV7indicesSSAAV7IndicesVvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Indices",
-                      "printedName": "Substring.UTF16View.Indices",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Indices",
-                          "printedName": "String.UTF16View.Indices",
-                          "usr": "s:SS9UTF16ViewV7IndicesV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:Ss9UTF16ViewV5index5afterSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "formIndex",
-              "printedName": "formIndex(after:)",
-              "declKind": "Func",
-              "usr": "s:Ss9UTF16ViewV9formIndex5afterySS0D0Vz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(_:offsetBy:)",
-              "declKind": "Func",
-              "usr": "s:Ss9UTF16ViewV5index_8offsetBySS5IndexVAF_SitF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(_:offsetBy:limitedBy:)",
-              "declKind": "Func",
-              "usr": "s:Ss9UTF16ViewV5index_8offsetBy07limitedE0SS5IndexVSgAG_SiAGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "Substring.UTF16View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "Substring.UTF16View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "distance",
-              "printedName": "distance(from:to:)",
-              "declKind": "Func",
-              "usr": "s:Ss9UTF16ViewV8distance4from2toSiSS5IndexV_AGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:Ss9UTF16ViewV5index6beforeSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "formIndex",
-              "printedName": "formIndex(before:)",
-              "declKind": "Func",
-              "usr": "s:Ss9UTF16ViewV9formIndex6beforeySS0D0Vz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss9UTF16ViewV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<Substring.UTF16View>",
-                  "usr": "s:s16IndexingIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UTF16View",
-                      "printedName": "Substring.UTF16View",
-                      "usr": "s:Ss9UTF16ViewV"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "utf16",
-          "printedName": "utf16",
-          "declKind": "Var",
-          "usr": "s:Ss5utf16Ss9UTF16ViewVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UTF16View",
-              "printedName": "Substring.UTF16View",
-              "usr": "s:Ss9UTF16ViewV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss5utf16Ss9UTF16ViewVvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UTF16View",
-                  "printedName": "Substring.UTF16View",
-                  "usr": "s:Ss9UTF16ViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Setter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss5utf16Ss9UTF16ViewVvs",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "UTF16View",
-                  "printedName": "Substring.UTF16View",
-                  "usr": "s:Ss9UTF16ViewV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SsyS2s9UTF16ViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UTF16View",
-              "printedName": "Substring.UTF16View",
-              "usr": "s:Ss9UTF16ViewV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeDecl",
-          "name": "UnicodeScalarView",
-          "printedName": "UnicodeScalarView",
-          "declKind": "Struct",
-          "usr": "s:Ss17UnicodeScalarViewV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence",
-            "RangeReplaceableCollection"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss17UnicodeScalarViewV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss17UnicodeScalarViewV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "String.UnicodeScalarView.Indices",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DefaultIndices",
-                      "printedName": "DefaultIndices<String.UnicodeScalarView>",
-                      "usr": "s:SI",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "UnicodeScalarView",
-                          "printedName": "String.UnicodeScalarView",
-                          "usr": "s:SS17UnicodeScalarViewV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss17UnicodeScalarViewV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "String.UnicodeScalarView.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Scalar",
-                      "printedName": "Unicode.Scalar",
-                      "usr": "s:s7UnicodeO6ScalarV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss17UnicodeScalarViewV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnicodeScalarView",
-                  "printedName": "Substring.UnicodeScalarView",
-                  "usr": "s:Ss17UnicodeScalarViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "startIndex",
-              "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:Ss17UnicodeScalarViewV10startIndexSS0E0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss17UnicodeScalarViewV10startIndexSS0E0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "Substring.UnicodeScalarView.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "endIndex",
-              "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:Ss17UnicodeScalarViewV8endIndexSS0E0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss17UnicodeScalarViewV8endIndexSS0E0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "Substring.UnicodeScalarView.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "indices",
-              "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:Ss17UnicodeScalarViewV7indicesSIySSAAVGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "Substring.UnicodeScalarView.Indices",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DefaultIndices",
-                      "printedName": "DefaultIndices<String.UnicodeScalarView>",
-                      "usr": "s:SI",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "UnicodeScalarView",
-                          "printedName": "String.UnicodeScalarView",
-                          "usr": "s:SS17UnicodeScalarViewV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss17UnicodeScalarViewV7indicesSIySSAAVGvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Indices",
-                      "printedName": "Substring.UnicodeScalarView.Indices",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "DefaultIndices",
-                          "printedName": "DefaultIndices<String.UnicodeScalarView>",
-                          "usr": "s:SI",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UnicodeScalarView",
-                              "printedName": "String.UnicodeScalarView",
-                              "usr": "s:SS17UnicodeScalarViewV"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:Ss17UnicodeScalarViewV5index5afterSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "formIndex",
-              "printedName": "formIndex(after:)",
-              "declKind": "Func",
-              "usr": "s:Ss17UnicodeScalarViewV9formIndex5afterySS0E0Vz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(_:offsetBy:)",
-              "declKind": "Func",
-              "usr": "s:Ss17UnicodeScalarViewV5index_8offsetBySS5IndexVAF_SitF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(_:offsetBy:limitedBy:)",
-              "declKind": "Func",
-              "usr": "s:Ss17UnicodeScalarViewV5index_8offsetBy07limitedF0SS5IndexVSgAG_SiAGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "Substring.UnicodeScalarView.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "Substring.UnicodeScalarView.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "distance",
-              "printedName": "distance(from:to:)",
-              "declKind": "Func",
-              "usr": "s:Ss17UnicodeScalarViewV8distance4from2toSiSS5IndexV_AGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:Ss17UnicodeScalarViewV5index6beforeSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "formIndex",
-              "printedName": "formIndex(before:)",
-              "declKind": "Func",
-              "usr": "s:Ss17UnicodeScalarViewV9formIndex6beforeySS0E0Vz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Substring.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss17UnicodeScalarViewV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<Substring.UnicodeScalarView>",
-                  "usr": "s:s16IndexingIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnicodeScalarView",
-                      "printedName": "Substring.UnicodeScalarView",
-                      "usr": "s:Ss17UnicodeScalarViewV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Constructor",
-              "name": "init",
-              "printedName": "init()",
-              "declKind": "Constructor",
-              "usr": "s:Ss17UnicodeScalarViewVABycfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnicodeScalarView",
-                  "printedName": "Substring.UnicodeScalarView",
-                  "usr": "s:Ss17UnicodeScalarViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "replaceSubrange",
-              "printedName": "replaceSubrange(_:with:)",
-              "declKind": "Func",
-              "usr": "s:Ss17UnicodeScalarViewV15replaceSubrange_4withySnySS5IndexVG_xtSlRzs0A0O0B0V7ElementRtzlF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<C where C : Collection, C.Element == Substring.UnicodeScalarView.Element>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Substring.UnicodeScalarView.Index>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "Substring.UnicodeScalarView.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "C"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "unicodeScalars",
-          "printedName": "unicodeScalars",
-          "declKind": "Var",
-          "usr": "s:Ss14unicodeScalarsSs17UnicodeScalarViewVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnicodeScalarView",
-              "printedName": "Substring.UnicodeScalarView",
-              "usr": "s:Ss17UnicodeScalarViewV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss14unicodeScalarsSs17UnicodeScalarViewVvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnicodeScalarView",
-                  "printedName": "Substring.UnicodeScalarView",
-                  "usr": "s:Ss17UnicodeScalarViewV"
-                }
-              ]
-            },
-            {
-              "kind": "Setter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss14unicodeScalarsSs17UnicodeScalarViewVvs",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnicodeScalarView",
-                  "printedName": "Substring.UnicodeScalarView",
-                  "usr": "s:Ss17UnicodeScalarViewV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SsyS2s17UnicodeScalarViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnicodeScalarView",
-              "printedName": "Substring.UnicodeScalarView",
-              "usr": "s:Ss17UnicodeScalarViewV"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SsySsxcSTRzSJ7ElementRtzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : Sequence, S.Element == Character>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "append",
-          "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:Ss6append10contentsOfyx_tSTRzSJ7ElementRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : Sequence, S.Element == Character>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "lowercased",
-          "printedName": "lowercased()",
-          "declKind": "Func",
-          "usr": "s:Ss10lowercasedSSyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "uppercased",
-          "printedName": "uppercased()",
-          "declKind": "Func",
-          "usr": "s:Ss10uppercasedSSyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "filter",
-          "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:Ss6filterySSSbSJKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Substring.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Substring.Element)",
-                  "usr": "s:SJ",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "Substring.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Character",
-                          "printedName": "Character",
-                          "usr": "s:SJ"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "write",
-          "printedName": "write(_:)",
-          "declKind": "Func",
-          "usr": "s:Ss5writeyySSF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "write",
-          "printedName": "write(to:)",
-          "declKind": "Func",
-          "usr": "s:Ss5write2toyxz_ts16TextOutputStreamRzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Target where Target : TextOutputStream>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Target"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(unicodeScalarLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Ss20unicodeScalarLiteralSsSS_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "UnicodeScalarLiteralType",
-          "printedName": "UnicodeScalarLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss24UnicodeScalarLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(extendedGraphemeClusterLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Ss30extendedGraphemeClusterLiteralSsSS_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "ExtendedGraphemeClusterLiteralType",
-          "printedName": "ExtendedGraphemeClusterLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss34ExtendedGraphemeClusterLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(stringLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Ss13stringLiteralSsSS_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "StringLiteralType",
-          "printedName": "StringLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss17StringLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "CharacterView",
-          "printedName": "CharacterView",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss13CharacterViewa",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "characters",
-          "printedName": "characters",
-          "declKind": "Var",
-          "usr": "s:Ss10charactersSsvp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Substring",
-              "printedName": "Substring",
-              "usr": "s:Ss"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss10charactersSsvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Substring",
-                  "printedName": "Substring",
-                  "usr": "s:Ss"
-                }
-              ]
-            },
-            {
-              "kind": "Setter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss10charactersSsvs",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Substring",
-                  "printedName": "Substring",
-                  "usr": "s:Ss"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withMutableCharacters",
-          "printedName": "withMutableCharacters(_:)",
-          "declKind": "Func",
-          "usr": "s:Ss21withMutableCharactersyxxSszXElF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<R>",
-          "deprecated": true,
-          "mutating": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(inout Substring) -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(inout Substring)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "InOut",
-                      "printedName": "inout Substring"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customPlaygroundQuickLook",
-          "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:Ss25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "_PlaygroundQuickLook",
-              "printedName": "_PlaygroundQuickLook",
-              "usr": "s:s20_PlaygroundQuickLookO"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "_PlaygroundQuickLook",
-                  "printedName": "_PlaygroundQuickLook",
-                  "usr": "s:s20_PlaygroundQuickLookO"
-                }
-              ]
-            }
-          ]
-        }
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Unmanaged",
       "printedName": "Unmanaged",
-      "declKind": "Struct",
-      "usr": "s:s9UnmanagedV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Instance where Instance : AnyObject>",
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "Function",
-          "name": "fromOpaque",
-          "printedName": "fromOpaque(_:)",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV10fromOpaqueyAByxGSVFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
+          "kind": "Var",
+          "name": "_value",
+          "printedName": "_value",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Unmanaged",
-              "printedName": "Unmanaged<Instance>",
-              "usr": "s:s9UnmanagedV",
+              "name": "UnmanagedStorage",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Instance"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s9UnmanagedV6_valuexXuvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : AnyObject>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s9UnmanagedV6_valuexXuvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline",
+            "ReferenceOwnership"
+          ],
+          "ownership": 3,
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Function",
+          "name": "fromOpaque",
+          "printedName": "fromOpaque(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Unmanaged",
+              "printedName": "Unmanaged<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s9UnmanagedV"
             },
             {
               "kind": "TypeNominal",
@@ -98271,20 +105065,20 @@
               "printedName": "UnsafeRawPointer",
               "usr": "s:SV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV10fromOpaqueyAByxGSVFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : AnyObject>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "toOpaque",
           "printedName": "toOpaque()",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV8toOpaqueSvyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -98292,987 +105086,423 @@
               "printedName": "UnsafeMutableRawPointer",
               "usr": "s:Sv"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV8toOpaqueSvyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : AnyObject>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "passRetained",
           "printedName": "passRetained(_:)",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV12passRetainedyAByxGxFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Unmanaged",
-              "printedName": "Unmanaged<Instance>",
-              "usr": "s:s9UnmanagedV",
+              "printedName": "Unmanaged<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Instance"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s9UnmanagedV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Instance"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV12passRetainedyAByxGxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : AnyObject>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "passUnretained",
           "printedName": "passUnretained(_:)",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV14passUnretainedyAByxGxFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Unmanaged",
-              "printedName": "Unmanaged<Instance>",
-              "usr": "s:s9UnmanagedV",
+              "printedName": "Unmanaged<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Instance"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s9UnmanagedV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Instance"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV14passUnretainedyAByxGxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : AnyObject>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "takeUnretainedValue",
           "printedName": "takeUnretainedValue()",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV19takeUnretainedValuexyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Instance"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV19takeUnretainedValuexyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : AnyObject>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "takeRetainedValue",
           "printedName": "takeRetainedValue()",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV17takeRetainedValuexyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Instance"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV17takeRetainedValuexyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : AnyObject>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "retain",
           "printedName": "retain()",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV6retainAByxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Unmanaged",
-              "printedName": "Unmanaged<Instance>",
-              "usr": "s:s9UnmanagedV",
+              "printedName": "Unmanaged<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Instance"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s9UnmanagedV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV6retainAByxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : AnyObject>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "release",
           "printedName": "release()",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV7releaseyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV7releaseyyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : AnyObject>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "autorelease",
           "printedName": "autorelease()",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV11autoreleaseAByxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Unmanaged",
-              "printedName": "Unmanaged<Instance>",
-              "usr": "s:s9UnmanagedV",
+              "printedName": "Unmanaged<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Instance"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s9UnmanagedV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV11autoreleaseAByxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : AnyObject>",
+          "declAttributes": [
+            "Transparent"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s9UnmanagedV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : AnyObject>",
+      "declAttributes": [
+        "FixedLayout"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnsafeMutableBufferPointer",
       "printedName": "UnsafeMutableBufferPointer",
-      "declKind": "Struct",
-      "usr": "s:Sr",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "_HasContiguousBytes",
-        "Sequence",
-        "MutableCollection",
-        "RandomAccessCollection",
-        "Collection",
-        "BidirectionalCollection",
-        "CustomDebugStringConvertible"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
-          "name": "count",
-          "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:Sr5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sr5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "declAttributes": [
-                "Transparent"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:Sr8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Iterator",
-              "printedName": "UnsafeBufferPointer<Element>.Iterator",
-              "usr": "s:SR8IteratorV"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "makeIterator",
-          "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:Sr12makeIteratorSR0B0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Iterator",
-              "printedName": "UnsafeMutableBufferPointer<Element>.Iterator",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "UnsafeBufferPointer<τ_0_0>.Iterator",
-                  "usr": "s:SR8IteratorV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:Sr5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:Sr7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Int>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:Sr10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sr10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:Sr8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sr8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:Sr5index5afterS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:Sr9formIndex5afterySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:Sr5index6beforeS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:Sr9formIndex6beforeySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:Sr5index_8offsetByS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:Sr5index_8offsetBy07limitedC0SiSgSi_S2itF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "name": "_position",
+          "printedName": "_position",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:Sr8distance4from2toS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "indices",
-          "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:Sr7indicesSnySiGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Indices",
-              "printedName": "UnsafeMutableBufferPointer<Element>.Indices",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Int>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sr7indicesSnySiGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "UnsafeMutableBufferPointer<Element>.Indices",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Range",
-                      "printedName": "Range<Int>",
-                      "usr": "s:Sn",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Int",
-                          "printedName": "Int",
-                          "usr": "s:Si"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "swapAt",
-          "printedName": "swapAt(_:_:)",
-          "declKind": "Func",
-          "usr": "s:Sr6swapAtyySi_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:Sr7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:Sr11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<UnsafeMutableBufferPointer<Element>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafeMutableBufferPointer",
-                  "printedName": "UnsafeMutableBufferPointer<Element>",
-                  "usr": "s:Sr",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(start:count:)",
-          "declKind": "Constructor",
-          "usr": "s:Sr5start5countSryxGSpyxGSg_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeMutableBufferPointer",
-              "printedName": "UnsafeMutableBufferPointer<Element>",
-              "usr": "s:Sr",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UnsafeMutablePointer<Element>?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafeMutablePointer<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafeMutablePointer",
-                  "printedName": "UnsafeMutablePointer<Element>",
-                  "usr": "s:Sp",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(mutating:)",
-          "declKind": "Constructor",
-          "usr": "s:Sr8mutatingSryxGSRyxG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeMutableBufferPointer",
-              "printedName": "UnsafeMutableBufferPointer<Element>",
-              "usr": "s:Sr",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeBufferPointer",
-              "printedName": "UnsafeBufferPointer<Element>",
-              "usr": "s:SR",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(rebasing:)",
-          "declKind": "Constructor",
-          "usr": "s:Sr8rebasingSryxGs5SliceVyABG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeMutableBufferPointer",
-              "printedName": "UnsafeMutableBufferPointer<Element>",
-              "usr": "s:Sr",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<UnsafeMutableBufferPointer<Element>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafeMutableBufferPointer",
-                  "printedName": "UnsafeMutableBufferPointer<Element>",
-                  "usr": "s:Sr",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "deallocate",
-          "printedName": "deallocate()",
-          "declKind": "Func",
-          "usr": "s:Sr10deallocateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "allocate",
-          "printedName": "allocate(capacity:)",
-          "declKind": "Func",
-          "usr": "s:Sr8allocate8capacitySryxGSi_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeMutableBufferPointer",
-              "printedName": "UnsafeMutableBufferPointer<UnsafeMutableBufferPointer<Element>.Element>",
-              "usr": "s:Sr",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "UnsafeMutableBufferPointer<Element>.Element",
+                  "printedName": "UnsafeMutablePointer<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<UnsafeMutablePointer<τ_0_0>>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafeMutablePointer",
+                      "printedName": "UnsafeMutablePointer<τ_0_0>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
+                        }
+                      ],
+                      "usr": "s:Sp"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sr9_positionSpyxGSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sr9_positionSpyxGSgvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "count",
+          "printedName": "count",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sr5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sr5countSivp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Function",
+          "name": "makeIterator",
+          "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Iterator",
+              "printedName": "UnsafeBufferPointer<τ_0_0>.Iterator",
+              "usr": "s:SR8IteratorV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr12makeIteratorSR0B0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sr10startIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sr10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sr8endIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sr8endIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
             },
             {
               "kind": "TypeNominal",
@@ -99280,20 +105510,559 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr5index5afterS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr9formIndex5afterySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr5index6beforeS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr9formIndex6beforeySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr5index_8offsetByS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:limitedBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr5index_8offsetBy07limitedC0SiSgSi_S2itF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(from:to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr8distance4from2toS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "indices",
+          "printedName": "indices",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Int>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sr7indicesSnySiGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sr7indicesSnySiGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SryxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<UnsafeMutableBufferPointer<τ_0_0>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutableBufferPointer",
+                  "printedName": "UnsafeMutableBufferPointer<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:Sr"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Srys5SliceVySryxGGSnySiGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Function",
+          "name": "swapAt",
+          "printedName": "swapAt(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr6swapAtyySi_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(start:count:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutableBufferPointer",
+              "printedName": "UnsafeMutableBufferPointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sr"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<UnsafeMutablePointer<τ_0_0>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutablePointer",
+                  "printedName": "UnsafeMutablePointer<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:Sp"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sr5start5countSryxGSpyxGSg_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(mutating:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutableBufferPointer",
+              "printedName": "UnsafeMutableBufferPointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sr"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeBufferPointer",
+              "printedName": "UnsafeBufferPointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SR"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sr8mutatingSryxGSRyxG_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(rebasing:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutableBufferPointer",
+              "printedName": "UnsafeMutableBufferPointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sr"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<UnsafeMutableBufferPointer<τ_0_0>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutableBufferPointer",
+                  "printedName": "UnsafeMutableBufferPointer<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:Sr"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sr8rebasingSryxGs5SliceVyABG_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "deallocate",
+          "printedName": "deallocate()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr10deallocateyyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "allocate",
+          "printedName": "allocate(capacity:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutableBufferPointer",
+              "printedName": "UnsafeMutableBufferPointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sr"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr8allocate8capacitySryxGSi_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "initialize",
           "printedName": "initialize(repeating:)",
-          "declKind": "Func",
-          "usr": "s:Sr10initialize9repeatingyx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -99301,31 +106070,23 @@
               "printedName": "()"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "UnsafeMutableBufferPointer<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr10initialize9repeatingyx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "assign",
           "printedName": "assign(repeating:)",
-          "declKind": "Func",
-          "usr": "s:Sr6assign9repeatingyx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -99333,165 +106094,150 @@
               "printedName": "()"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "UnsafeMutableBufferPointer<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr6assign9repeatingyx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "withMemoryRebound",
           "printedName": "withMemoryRebound(to:_:)",
-          "declKind": "Func",
-          "usr": "s:Sr17withMemoryRebound2to_qd_0_qd__m_qd_0_Sryqd__GKXEtKr0_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, T, Result>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Result"
+              "printedName": "τ_1_1"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_1_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
               ]
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(UnsafeMutableBufferPointer<T>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(UnsafeMutableBufferPointer<τ_1_0>) throws -> τ_1_1",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Result"
+                  "printedName": "τ_1_1"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeMutableBufferPointer<T>)",
-                  "usr": "s:Sr",
+                  "name": "UnsafeMutableBufferPointer",
+                  "printedName": "UnsafeMutableBufferPointer<τ_1_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "UnsafeMutableBufferPointer",
-                      "printedName": "UnsafeMutableBufferPointer<T>",
-                      "usr": "s:Sr",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "T"
-                        }
-                      ]
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_1_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sr"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr17withMemoryRebound2to_qd_0_qd__m_qd_0_Sryqd__GKXEtKr0_lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0, τ_1_1>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Var",
           "name": "baseAddress",
           "printedName": "baseAddress",
-          "declKind": "Var",
-          "usr": "s:Sr11baseAddressSpyxGSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafeMutablePointer<Element>?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafeMutablePointer<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafeMutablePointer",
-                  "printedName": "UnsafeMutablePointer<Element>",
-                  "usr": "s:Sp",
+                  "printedName": "UnsafeMutablePointer<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Element"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sr11baseAddressSpyxGSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "UnsafeMutablePointer<Element>?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<UnsafeMutablePointer<τ_0_0>>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafeMutablePointer",
-                      "printedName": "UnsafeMutablePointer<Element>",
-                      "usr": "s:Sp",
+                      "printedName": "UnsafeMutablePointer<τ_0_0>",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
-                          "printedName": "Element"
+                          "printedName": "τ_0_0"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sp"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sr11baseAddressSpyxGSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sr11baseAddressSpyxGSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Sr16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -99503,11 +106249,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sr16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -99515,37 +106256,719 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sr16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sr16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "initialize",
           "printedName": "initialize(from:)",
-          "declKind": "Func",
-          "usr": "s:Sr10initialize4from8IteratorQyd___Sitqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(S.Iterator, UnsafeMutableBufferPointer<Element>.Index)",
+              "printedName": "(τ_1_0.Iterator, Int)",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "S.Iterator"
+                  "printedName": "τ_1_0.Iterator"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "UnsafeMutableBufferPointer<Element>.Index",
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr10initialize4from8IteratorQyd___Sitqd___t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:Sr",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "_HasContiguousBytes",
+        "Sequence",
+        "MutableCollection",
+        "RandomAccessCollection",
+        "Collection",
+        "BidirectionalCollection",
+        "CustomDebugStringConvertible"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "UnsafeBufferPointer",
+      "printedName": "UnsafeBufferPointer",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_position",
+          "printedName": "_position",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<UnsafePointer<τ_0_0>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafePointer",
+                  "printedName": "UnsafePointer<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:SP"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<UnsafePointer<τ_0_0>>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafePointer",
+                      "printedName": "UnsafePointer<τ_0_0>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
+                        }
+                      ],
+                      "usr": "s:SP"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SR9_positionSPyxGSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SR9_positionSPyxGSgvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "count",
+          "printedName": "count",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SR5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SR5countSivp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "Iterator",
+          "printedName": "Iterator",
+          "children": [
+            {
+              "kind": "Var",
+              "name": "_position",
+              "printedName": "_position",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<UnsafePointer<τ_0_0>>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafePointer",
+                      "printedName": "UnsafePointer<τ_0_0>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
+                        }
+                      ],
+                      "usr": "s:SP"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<UnsafePointer<τ_0_0>>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UnsafePointer",
+                          "printedName": "UnsafePointer<τ_0_0>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "GenericTypeParam",
+                              "printedName": "τ_0_0"
+                            }
+                          ],
+                          "usr": "s:SP"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SR8IteratorV9_positionSPyxGSgvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SR8IteratorV9_positionSPyxGSgvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "HasInitialValue",
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_end",
+              "printedName": "_end",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<UnsafePointer<τ_0_0>>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafePointer",
+                      "printedName": "UnsafePointer<τ_0_0>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
+                        }
+                      ],
+                      "usr": "s:SP"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<UnsafePointer<τ_0_0>>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UnsafePointer",
+                          "printedName": "UnsafePointer<τ_0_0>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "GenericTypeParam",
+                              "printedName": "τ_0_0"
+                            }
+                          ],
+                          "usr": "s:SP"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SR8IteratorV4_endSPyxGSgvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SR8IteratorV4_endSPyxGSgvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "HasInitialValue",
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 1,
+              "hasStorage": true
+            },
+            {
+              "kind": "Function",
+              "name": "next",
+              "printedName": "next()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SR8IteratorV4nextxSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SR8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "makeIterator",
+          "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Iterator",
+              "printedName": "UnsafeBufferPointer<τ_0_0>.Iterator",
+              "usr": "s:SR8IteratorV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR12makeIteratorSR0B0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SR10startIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SR10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SR8endIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SR8endIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR5index5afterS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR9formIndex5afterySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR5index6beforeS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR9formIndex6beforeySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR5index_8offsetByS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:limitedBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR5index_8offsetBy07limitedC0SiSgSi_S2itF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(from:to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR8distance4from2toS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "indices",
+          "printedName": "indices",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Int>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -99553,28 +106976,474 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SR7indicesSnySiGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SR7indicesSnySiGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SRyxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<UnsafeBufferPointer<τ_0_0>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeBufferPointer",
+                  "printedName": "UnsafeBufferPointer<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:SR"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SRys5SliceVySRyxGGSnySiGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(start:count:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeBufferPointer",
+              "printedName": "UnsafeBufferPointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SR"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<UnsafePointer<τ_0_0>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafePointer",
+                  "printedName": "UnsafePointer<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:SP"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SR5start5countSRyxGSPyxGSg_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeBufferPointer",
+              "printedName": "UnsafeBufferPointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SR"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutableBufferPointer",
+              "printedName": "UnsafeMutableBufferPointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sr"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SRySRyxGSryxGcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(rebasing:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeBufferPointer",
+              "printedName": "UnsafeBufferPointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SR"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<UnsafeBufferPointer<τ_0_0>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeBufferPointer",
+                  "printedName": "UnsafeBufferPointer<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:SR"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SR8rebasingSRyxGs5SliceVyABG_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(rebasing:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeBufferPointer",
+              "printedName": "UnsafeBufferPointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SR"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<UnsafeMutableBufferPointer<τ_0_0>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutableBufferPointer",
+                  "printedName": "UnsafeMutableBufferPointer<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:Sr"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SR8rebasingSRyxGs5SliceVySryxGG_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "deallocate",
+          "printedName": "deallocate()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR10deallocateyyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "withMemoryRebound",
+          "printedName": "withMemoryRebound(to:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_1_0.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_0"
                 }
               ]
             },
             {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafeBufferPointer<τ_1_0>) throws -> τ_1_1",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_1_1"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeBufferPointer",
+                  "printedName": "UnsafeBufferPointer<τ_1_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_1_0"
+                    }
+                  ],
+                  "usr": "s:SR"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR17withMemoryRebound2to_qd_0_qd__m_qd_0_SRyqd__GKXEtKr0_lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0, τ_1_1>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Var",
+          "name": "baseAddress",
+          "printedName": "baseAddress",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<UnsafePointer<τ_0_0>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafePointer",
+                  "printedName": "UnsafePointer<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:SP"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<UnsafePointer<τ_0_0>>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafePointer",
+                      "printedName": "UnsafePointer<τ_0_0>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
+                        }
+                      ],
+                      "usr": "s:SP"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SR11baseAddressSPyxGSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SR11baseAddressSPyxGSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SR16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SR16debugDescriptionSSvp",
+          "moduleName": "Swift"
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "UnsafeBufferPointer",
-      "printedName": "UnsafeBufferPointer",
+      ],
       "declKind": "Struct",
       "usr": "s:SR",
-      "location": "",
       "moduleName": "Swift",
-      "genericSig": "<Element>",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "_HasContiguousBytes",
         "Sequence",
@@ -99582,1573 +107451,22 @@
         "RandomAccessCollection",
         "BidirectionalCollection",
         "CustomDebugStringConvertible"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Var",
-          "name": "count",
-          "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:SR5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SR5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "declAttributes": [
-                "Transparent"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeDecl",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:SR8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "conformingProtocols": [
-            "IteratorProtocol"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "Function",
-              "name": "next",
-              "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:SR8IteratorV4nextxSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "Element?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:SR8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "makeIterator",
-          "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:SR12makeIteratorSR0B0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Iterator",
-              "printedName": "UnsafeBufferPointer<Element>.Iterator",
-              "usr": "s:SR8IteratorV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:SR5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:SR7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Int>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:SR10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SR10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:SR8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SR8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:SR5index5afterS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:SR9formIndex5afterySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:SR5index6beforeS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:SR9formIndex6beforeySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SR5index_8offsetByS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SR5index_8offsetBy07limitedC0SiSgSi_S2itF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SR8distance4from2toS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "indices",
-          "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:SR7indicesSnySiGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Indices",
-              "printedName": "UnsafeBufferPointer<Element>.Indices",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Int>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SR7indicesSnySiGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "UnsafeBufferPointer<Element>.Indices",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Range",
-                      "printedName": "Range<Int>",
-                      "usr": "s:Sn",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Int",
-                          "printedName": "Int",
-                          "usr": "s:Si"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:SR7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:SR11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<UnsafeBufferPointer<Element>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafeBufferPointer",
-                  "printedName": "UnsafeBufferPointer<Element>",
-                  "usr": "s:SR",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(start:count:)",
-          "declKind": "Constructor",
-          "usr": "s:SR5start5countSRyxGSPyxGSg_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeBufferPointer",
-              "printedName": "UnsafeBufferPointer<Element>",
-              "usr": "s:SR",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UnsafePointer<Element>?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafePointer",
-                  "printedName": "UnsafePointer<Element>",
-                  "usr": "s:SP",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SRySRyxGSryxGcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeBufferPointer",
-              "printedName": "UnsafeBufferPointer<Element>",
-              "usr": "s:SR",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeMutableBufferPointer",
-              "printedName": "UnsafeMutableBufferPointer<Element>",
-              "usr": "s:Sr",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(rebasing:)",
-          "declKind": "Constructor",
-          "usr": "s:SR8rebasingSRyxGs5SliceVyABG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeBufferPointer",
-              "printedName": "UnsafeBufferPointer<Element>",
-              "usr": "s:SR",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<UnsafeBufferPointer<Element>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafeBufferPointer",
-                  "printedName": "UnsafeBufferPointer<Element>",
-                  "usr": "s:SR",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(rebasing:)",
-          "declKind": "Constructor",
-          "usr": "s:SR8rebasingSRyxGs5SliceVySryxGG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeBufferPointer",
-              "printedName": "UnsafeBufferPointer<Element>",
-              "usr": "s:SR",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<UnsafeMutableBufferPointer<Element>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafeMutableBufferPointer",
-                  "printedName": "UnsafeMutableBufferPointer<Element>",
-                  "usr": "s:Sr",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "deallocate",
-          "printedName": "deallocate()",
-          "declKind": "Func",
-          "usr": "s:SR10deallocateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withMemoryRebound",
-          "printedName": "withMemoryRebound(to:_:)",
-          "declKind": "Func",
-          "usr": "s:SR17withMemoryRebound2to_qd_0_qd__m_qd_0_SRyqd__GKXEtKr0_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, T, Result>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Result"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "T.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafeBufferPointer<T>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Result"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeBufferPointer<T>)",
-                  "usr": "s:SR",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeBufferPointer",
-                      "printedName": "UnsafeBufferPointer<T>",
-                      "usr": "s:SR",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "T"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "baseAddress",
-          "printedName": "baseAddress",
-          "declKind": "Var",
-          "usr": "s:SR11baseAddressSPyxGSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UnsafePointer<Element>?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafePointer",
-                  "printedName": "UnsafePointer<Element>",
-                  "usr": "s:SP",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SR11baseAddressSPyxGSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "UnsafePointer<Element>?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafePointer",
-                      "printedName": "UnsafePointer<Element>",
-                      "usr": "s:SP",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Element"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "debugDescription",
-          "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:SR16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SR16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        }
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnsafeMutableRawBufferPointer",
       "printedName": "UnsafeMutableRawBufferPointer",
-      "declKind": "Struct",
-      "usr": "s:Sw",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Sequence",
-        "MutableCollection",
-        "Collection",
-        "RandomAccessCollection",
-        "BidirectionalCollection",
-        "CustomDebugStringConvertible"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:Sw8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Iterator",
-              "printedName": "UnsafeRawBufferPointer.Iterator",
-              "usr": "s:SW8IteratorV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:Sw11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<UnsafeMutableRawBufferPointer>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafeMutableRawBufferPointer",
-                  "printedName": "UnsafeMutableRawBufferPointer",
-                  "usr": "s:Sw"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "makeIterator",
-          "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:Sw12makeIteratorSW0B0VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Iterator",
-              "printedName": "UnsafeMutableRawBufferPointer.Iterator",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "UnsafeRawBufferPointer.Iterator",
-                  "usr": "s:SW8IteratorV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:Sw7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:Sw5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:Sw7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Int>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
           "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:Sw10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "name": "_position",
+          "printedName": "_position",
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "UnsafeMutableRawBufferPointer.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sw10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "UnsafeMutableRawBufferPointer.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:Sw8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "UnsafeMutableRawBufferPointer.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sw8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "UnsafeMutableRawBufferPointer.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "indices",
-          "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:Sw7indicesSnySiGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Indices",
-              "printedName": "UnsafeMutableRawBufferPointer.Indices",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Int>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sw7indicesSnySiGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "UnsafeMutableRawBufferPointer.Indices",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Range",
-                      "printedName": "Range<Int>",
-                      "usr": "s:Sn",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Int",
-                          "printedName": "Int",
-                          "usr": "s:Si"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "swapAt",
-          "printedName": "swapAt(_:_:)",
-          "declKind": "Func",
-          "usr": "s:Sw6swapAtyySi_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "count",
-          "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:Sw5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sw5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "allocate",
-          "printedName": "allocate(byteCount:alignment:)",
-          "declKind": "Func",
-          "usr": "s:Sw8allocate9byteCount9alignmentSwSi_SitFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeMutableRawBufferPointer",
-              "printedName": "UnsafeMutableRawBufferPointer",
-              "usr": "s:Sw"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "deallocate",
-          "printedName": "deallocate()",
-          "declKind": "Func",
-          "usr": "s:Sw10deallocateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "load",
-          "printedName": "load(fromByteOffset:as:)",
-          "declKind": "Func",
-          "usr": "s:Sw4load14fromByteOffset2asxSi_xmtlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "hasDefaultArg": true,
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "T.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "storeBytes",
-          "printedName": "storeBytes(of:toByteOffset:as:)",
-          "declKind": "Func",
-          "usr": "s:Sw10storeBytes2of12toByteOffset2asyx_SixmtlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "hasDefaultArg": true,
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "T.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "copyMemory",
-          "printedName": "copyMemory(from:)",
-          "declKind": "Func",
-          "usr": "s:Sw10copyMemory4fromySW_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeRawBufferPointer",
-              "printedName": "UnsafeRawBufferPointer",
-              "usr": "s:SW"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "copyBytes",
-          "printedName": "copyBytes(from:)",
-          "declKind": "Func",
-          "usr": "s:Sw9copyBytes4fromyx_tSlRzs5UInt8V7ElementRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<C where C : Collection, C.Element == UInt8>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "C"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(start:count:)",
-          "declKind": "Constructor",
-          "usr": "s:Sw5start5countSwSvSg_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeMutableRawBufferPointer",
-              "printedName": "UnsafeMutableRawBufferPointer",
-              "usr": "s:Sw"
-            },
-            {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafeMutableRawPointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafeMutableRawPointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -101156,176 +107474,18 @@
                   "printedName": "UnsafeMutableRawPointer",
                   "usr": "s:Sv"
                 }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SwyS2wcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeMutableRawBufferPointer",
-              "printedName": "UnsafeMutableRawBufferPointer",
-              "usr": "s:Sw"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeMutableRawBufferPointer",
-              "printedName": "UnsafeMutableRawBufferPointer",
-              "usr": "s:Sw"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(mutating:)",
-          "declKind": "Constructor",
-          "usr": "s:Sw8mutatingSwSW_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeMutableRawBufferPointer",
-              "printedName": "UnsafeMutableRawBufferPointer",
-              "usr": "s:Sw"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeRawBufferPointer",
-              "printedName": "UnsafeRawBufferPointer",
-              "usr": "s:SW"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SwySwSryxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeMutableRawBufferPointer",
-              "printedName": "UnsafeMutableRawBufferPointer",
-              "usr": "s:Sw"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeMutableBufferPointer",
-              "printedName": "UnsafeMutableBufferPointer<T>",
-              "usr": "s:Sr",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(rebasing:)",
-          "declKind": "Constructor",
-          "usr": "s:Sw8rebasingSws5SliceVySwG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeMutableRawBufferPointer",
-              "printedName": "UnsafeMutableRawBufferPointer",
-              "usr": "s:Sw"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<UnsafeMutableRawBufferPointer>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafeMutableRawBufferPointer",
-                  "printedName": "UnsafeMutableRawBufferPointer",
-                  "usr": "s:Sw"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "baseAddress",
-          "printedName": "baseAddress",
-          "declKind": "Var",
-          "usr": "s:Sw11baseAddressSvSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UnsafeMutableRawPointer?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafeMutableRawPointer",
-                  "printedName": "UnsafeMutableRawPointer",
-                  "usr": "s:Sv"
-                }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sw11baseAddressSvSgvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "UnsafeMutableRawPointer?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<UnsafeMutableRawPointer>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -101333,202 +107493,368 @@
                       "printedName": "UnsafeMutableRawPointer",
                       "usr": "s:Sv"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sw9_positionSvSgvg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "initializeMemory",
-          "printedName": "initializeMemory(as:repeating:)",
-          "declKind": "Func",
-          "usr": "s:Sw16initializeMemory2as9repeatingSryxGxm_xtlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeMutableBufferPointer",
-              "printedName": "UnsafeMutableBufferPointer<T>",
-              "usr": "s:Sr",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "T.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "initializeMemory",
-          "printedName": "initializeMemory(as:from:)",
-          "declKind": "Func",
-          "usr": "s:Sw16initializeMemory2as4from8IteratorQz9unwritten_Sry7ElementQzG11initializedtAHm_xtSTRzlF",
-          "location": "",
+          "declKind": "Var",
+          "usr": "s:Sw9_positionSvSgvp",
           "moduleName": "Swift",
-          "genericSig": "<S where S : Sequence>",
+          "isInternal": true,
           "declAttributes": [
-            "Inlinable"
+            "UsableFromInline"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(unwritten: S.Iterator, initialized: UnsafeMutableBufferPointer<S.Element>)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "S.Iterator"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafeMutableBufferPointer",
-                  "printedName": "UnsafeMutableBufferPointer<S.Element>",
-                  "usr": "s:Sr",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "S.Element"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "S.Element.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "S.Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "bindMemory",
-          "printedName": "bindMemory(to:)",
-          "declKind": "Func",
-          "usr": "s:Sw10bindMemory2toSryxGxm_tlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeMutableBufferPointer",
-              "printedName": "UnsafeMutableBufferPointer<T>",
-              "usr": "s:Sr",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Metatype",
-              "printedName": "T.Type",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            }
-          ]
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Var",
-          "name": "debugDescription",
-          "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Sw16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
+          "name": "_end",
+          "printedName": "_end",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
+              "name": "Optional",
+              "printedName": "Optional<UnsafeMutableRawPointer>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutableRawPointer",
+                  "printedName": "UnsafeMutableRawPointer",
+                  "usr": "s:Sv"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sw16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
+                  "name": "Optional",
+                  "printedName": "Optional<UnsafeMutableRawPointer>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafeMutableRawPointer",
+                      "printedName": "UnsafeMutableRawPointer",
+                      "usr": "s:Sv"
+                    }
+                  ],
+                  "usr": "s:Sq"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sw4_endSvSgvg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sw4_endSvSgvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Function",
+          "name": "makeIterator",
+          "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Iterator",
+              "printedName": "UnsafeRawBufferPointer.Iterator",
+              "usr": "s:SW8IteratorV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw12makeIteratorSW0B0VyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sw10startIndexSivg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sw10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sw8endIndexSivg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sw8endIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "indices",
+          "printedName": "indices",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Int>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sw7indicesSnySiGvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sw7indicesSnySiGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Swys5UInt8VSicip",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<UnsafeMutableRawBufferPointer>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutableRawBufferPointer",
+                  "printedName": "UnsafeMutableRawBufferPointer",
+                  "usr": "s:Sw"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Swys5SliceVySwGSnySiGcip",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Function",
+          "name": "swapAt",
+          "printedName": "swapAt(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw6swapAtyySi_SitF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "count",
+          "printedName": "count",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sw5countSivg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sw5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "allocate",
-          "printedName": "allocate(count:)",
-          "declKind": "Func",
-          "usr": "s:Sw8allocate5countSwSi_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Available"
-          ],
+          "printedName": "allocate(byteCount:alignment:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -101541,514 +107867,49 @@
               "name": "Int",
               "printedName": "Int",
               "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "copyBytes",
-          "printedName": "copyBytes(from:)",
-          "declKind": "Func",
-          "usr": "s:Sw9copyBytes4fromySW_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
             },
             {
               "kind": "TypeNominal",
-              "name": "UnsafeRawBufferPointer",
-              "printedName": "UnsafeRawBufferPointer",
-              "usr": "s:SW"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "UnsafeRawBufferPointer",
-      "printedName": "UnsafeRawBufferPointer",
-      "declKind": "Struct",
-      "usr": "s:SW",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Sequence",
-        "Collection",
-        "RandomAccessCollection",
-        "BidirectionalCollection",
-        "CustomDebugStringConvertible"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "TypeDecl",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:SW8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "IteratorProtocol",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "Function",
-              "name": "next",
-              "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:SW8IteratorV4nexts5UInt8VSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "UInt8?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt8",
-                      "printedName": "UInt8",
-                      "usr": "s:s5UInt8V"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:SW8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt8",
-                  "printedName": "UInt8",
-                  "usr": "s:s5UInt8V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:SW8IteratorVAAa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "UnsafeRawBufferPointer.Iterator",
-                  "usr": "s:SW8IteratorV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:SW8IteratorV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnySequence",
-                  "printedName": "AnySequence<UnsafeRawBufferPointer.Iterator.Element>",
-                  "usr": "s:s11AnySequenceV",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "UnsafeRawBufferPointer.Iterator.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "UInt8",
-                          "printedName": "UInt8",
-                          "usr": "s:s5UInt8V"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:SW11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<UnsafeRawBufferPointer>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafeRawBufferPointer",
-                  "printedName": "UnsafeRawBufferPointer",
-                  "usr": "s:SW"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "makeIterator",
-          "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:SW12makeIteratorSW0B0VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Iterator",
-              "printedName": "UnsafeRawBufferPointer.Iterator",
-              "usr": "s:SW8IteratorV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:SW7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:SW5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
               "name": "Int",
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:SW7Indicesa",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw8allocate9byteCount9alignmentSwSi_SitFZ",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Int>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:SW10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
+          "static": true,
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "UnsafeRawBufferPointer.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SW10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "UnsafeRawBufferPointer.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:SW8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "UnsafeRawBufferPointer.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SW8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "UnsafeRawBufferPointer.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "indices",
-          "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:SW7indicesSnySiGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Indices",
-              "printedName": "UnsafeRawBufferPointer.Indices",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Int>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SW7indicesSnySiGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Indices",
-                  "printedName": "UnsafeRawBufferPointer.Indices",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Range",
-                      "printedName": "Range<Int>",
-                      "usr": "s:Sn",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Int",
-                          "printedName": "Int",
-                          "usr": "s:Si"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "count",
-          "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:SW5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SW5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
           ]
         },
         {
           "kind": "Function",
           "name": "deallocate",
           "printedName": "deallocate()",
-          "declKind": "Func",
-          "usr": "s:SW10deallocateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw10deallocateyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "load",
           "printedName": "load(fromByteOffset:as:)",
-          "declKind": "Func",
-          "usr": "s:SW4load14fromByteOffset2asxSi_xmtlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -102060,28 +107921,1153 @@
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_0_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw4load14fromByteOffset2asxSi_xmtlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "storeBytes",
+          "printedName": "storeBytes(of:toByteOffset:as:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "hasDefaultArg": true,
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_0_0.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw10storeBytes2of12toByteOffset2asyx_SixmtlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "copyMemory",
+          "printedName": "copyMemory(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeRawBufferPointer",
+              "printedName": "UnsafeRawBufferPointer",
+              "usr": "s:SW"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw10copyMemory4fromySW_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "copyBytes",
+          "printedName": "copyBytes(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw9copyBytes4fromyx_tSlRzs5UInt8V7ElementRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection, τ_0_0.Element == UInt8>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(start:count:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutableRawBufferPointer",
+              "printedName": "UnsafeMutableRawBufferPointer",
+              "usr": "s:Sw"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<UnsafeMutableRawPointer>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutableRawPointer",
+                  "printedName": "UnsafeMutableRawPointer",
+                  "usr": "s:Sv"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
           "declKind": "Constructor",
-          "usr": "s:SW5start5countSWSVSg_Sitcfc",
-          "location": "",
+          "usr": "s:Sw5start5countSwSvSg_Sitcfc",
           "moduleName": "Swift",
           "declAttributes": [
             "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutableRawBufferPointer",
+              "printedName": "UnsafeMutableRawBufferPointer",
+              "usr": "s:Sw"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutableRawBufferPointer",
+              "printedName": "UnsafeMutableRawBufferPointer",
+              "usr": "s:Sw"
+            }
           ],
+          "declKind": "Constructor",
+          "usr": "s:SwyS2wcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(mutating:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutableRawBufferPointer",
+              "printedName": "UnsafeMutableRawBufferPointer",
+              "usr": "s:Sw"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeRawBufferPointer",
+              "printedName": "UnsafeRawBufferPointer",
+              "usr": "s:SW"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sw8mutatingSwSW_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutableRawBufferPointer",
+              "printedName": "UnsafeMutableRawBufferPointer",
+              "usr": "s:Sw"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutableBufferPointer",
+              "printedName": "UnsafeMutableBufferPointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sr"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SwySwSryxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(rebasing:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutableRawBufferPointer",
+              "printedName": "UnsafeMutableRawBufferPointer",
+              "usr": "s:Sw"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<UnsafeMutableRawBufferPointer>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutableRawBufferPointer",
+                  "printedName": "UnsafeMutableRawBufferPointer",
+                  "usr": "s:Sw"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sw8rebasingSws5SliceVySwG_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "baseAddress",
+          "printedName": "baseAddress",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<UnsafeMutableRawPointer>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutableRawPointer",
+                  "printedName": "UnsafeMutableRawPointer",
+                  "usr": "s:Sv"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<UnsafeMutableRawPointer>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafeMutableRawPointer",
+                      "printedName": "UnsafeMutableRawPointer",
+                      "usr": "s:Sv"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sw11baseAddressSvSgvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sw11baseAddressSvSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "initializeMemory",
+          "printedName": "initializeMemory(as:repeating:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutableBufferPointer",
+              "printedName": "UnsafeMutableBufferPointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sr"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_0_0.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw16initializeMemory2as9repeatingSryxGxm_xtlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "initializeMemory",
+          "printedName": "initializeMemory(as:from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(unwritten: τ_0_0.Iterator, initialized: UnsafeMutableBufferPointer<τ_0_0.Element>)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Iterator"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutableBufferPointer",
+                  "printedName": "UnsafeMutableBufferPointer<τ_0_0.Element>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Element"
+                    }
+                  ],
+                  "usr": "s:Sr"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_0_0.Element.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw16initializeMemory2as4from8IteratorQz9unwritten_Sry7ElementQzG11initializedtAHm_xtSTRzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "bindMemory",
+          "printedName": "bindMemory(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutableBufferPointer",
+              "printedName": "UnsafeMutableBufferPointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sr"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_0_0.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw10bindMemory2toSryxGxm_tlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sw16debugDescriptionSSvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sw16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "allocate",
+          "printedName": "allocate(count:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutableRawBufferPointer",
+              "printedName": "UnsafeMutableRawBufferPointer",
+              "usr": "s:Sw"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw8allocate5countSwSi_tFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "copyBytes",
+          "printedName": "copyBytes(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeRawBufferPointer",
+              "printedName": "UnsafeRawBufferPointer",
+              "usr": "s:SW"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw9copyBytes4fromySW_tF",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
+          ]
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:Sw",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "MutableCollection",
+        "Collection",
+        "RandomAccessCollection",
+        "BidirectionalCollection",
+        "CustomDebugStringConvertible"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "UnsafeRawBufferPointer",
+      "printedName": "UnsafeRawBufferPointer",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "_position",
+          "printedName": "_position",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<UnsafeRawPointer>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeRawPointer",
+                  "printedName": "UnsafeRawPointer",
+                  "usr": "s:SV"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<UnsafeRawPointer>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafeRawPointer",
+                      "printedName": "UnsafeRawPointer",
+                      "usr": "s:SV"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SW9_positionSVSgvg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SW9_positionSVSgvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_end",
+          "printedName": "_end",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<UnsafeRawPointer>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeRawPointer",
+                  "printedName": "UnsafeRawPointer",
+                  "usr": "s:SV"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<UnsafeRawPointer>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafeRawPointer",
+                      "printedName": "UnsafeRawPointer",
+                      "usr": "s:SV"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SW4_endSVSgvg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SW4_endSVSgvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "Iterator",
+          "printedName": "Iterator",
+          "children": [
+            {
+              "kind": "Var",
+              "name": "_position",
+              "printedName": "_position",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<UnsafeRawPointer>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafeRawPointer",
+                      "printedName": "UnsafeRawPointer",
+                      "usr": "s:SV"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<UnsafeRawPointer>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UnsafeRawPointer",
+                          "printedName": "UnsafeRawPointer",
+                          "usr": "s:SV"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SW8IteratorV9_positionSVSgvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SW8IteratorV9_positionSVSgvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "HasInitialValue",
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_end",
+              "printedName": "_end",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<UnsafeRawPointer>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafeRawPointer",
+                      "printedName": "UnsafeRawPointer",
+                      "usr": "s:SV"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<UnsafeRawPointer>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UnsafeRawPointer",
+                          "printedName": "UnsafeRawPointer",
+                          "usr": "s:SV"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SW8IteratorV4_endSVSgvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SW8IteratorV4_endSVSgvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "HasInitialValue",
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 1,
+              "hasStorage": true
+            },
+            {
+              "kind": "Function",
+              "name": "next",
+              "printedName": "next()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<UInt8>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt8",
+                      "printedName": "UInt8",
+                      "usr": "s:s5UInt8V"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SW8IteratorV4nexts5UInt8VSgyF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SW8IteratorV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "Sequence"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "makeIterator",
+          "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Iterator",
+              "printedName": "UnsafeRawBufferPointer.Iterator",
+              "usr": "s:SW8IteratorV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SW12makeIteratorSW0B0VyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SW10startIndexSivg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SW10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SW8endIndexSivg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SW8endIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "indices",
+          "printedName": "indices",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Int>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SW7indicesSnySiGvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SW7indicesSnySiGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SWys5UInt8VSicip",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<UnsafeRawBufferPointer>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeRawBufferPointer",
+                  "printedName": "UnsafeRawBufferPointer",
+                  "usr": "s:SW"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SWys5SliceVySWGSnySiGcip",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "count",
+          "printedName": "count",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SW5countSivg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SW5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "deallocate",
+          "printedName": "deallocate()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SW10deallocateyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "load",
+          "printedName": "load(fromByteOffset:as:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "hasDefaultArg": true,
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Metatype",
+              "printedName": "τ_0_0.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SW4load14fromByteOffset2asxSi_xmtlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(start:count:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -102092,8 +109078,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafeRawPointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafeRawPointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -102101,7 +109086,8 @@
                   "printedName": "UnsafeRawPointer",
                   "usr": "s:SV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -102109,19 +109095,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SW5start5countSWSVSg_Sitcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SWySWSwcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102135,19 +109120,18 @@
               "printedName": "UnsafeMutableRawBufferPointer",
               "usr": "s:Sw"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SWySWSwcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SWyS2Wcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102161,20 +109145,18 @@
               "printedName": "UnsafeRawBufferPointer",
               "usr": "s:SW"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SWyS2Wcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SWySWSryxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102185,30 +109167,29 @@
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutableBufferPointer",
-              "printedName": "UnsafeMutableBufferPointer<T>",
-              "usr": "s:Sr",
+              "printedName": "UnsafeMutableBufferPointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sr"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SWySWSryxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SWySWSRyxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102219,29 +109200,29 @@
             {
               "kind": "TypeNominal",
               "name": "UnsafeBufferPointer",
-              "printedName": "UnsafeBufferPointer<T>",
-              "usr": "s:SR",
+              "printedName": "UnsafeBufferPointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:SR"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SWySWSRyxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(rebasing:)",
-          "declKind": "Constructor",
-          "usr": "s:SW8rebasingSWs5SliceVySWG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102253,7 +109234,6 @@
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<UnsafeRawBufferPointer>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -102261,21 +109241,21 @@
                   "printedName": "UnsafeRawBufferPointer",
                   "usr": "s:SW"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SW8rebasingSWs5SliceVySWG_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(rebasing:)",
-          "declKind": "Constructor",
-          "usr": "s:SW8rebasingSWs5SliceVySwG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102287,7 +109267,6 @@
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<UnsafeMutableRawBufferPointer>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -102295,27 +109274,26 @@
                   "printedName": "UnsafeMutableRawBufferPointer",
                   "usr": "s:Sw"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SW8rebasingSWs5SliceVySwG_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "baseAddress",
           "printedName": "baseAddress",
-          "declKind": "Var",
-          "usr": "s:SW11baseAddressSVSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafeRawPointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafeRawPointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -102323,22 +109301,18 @@
                   "printedName": "UnsafeRawPointer",
                   "usr": "s:SV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SW11baseAddressSVSgvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "UnsafeRawPointer?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<UnsafeRawPointer>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -102346,61 +109320,66 @@
                       "printedName": "UnsafeRawPointer",
                       "usr": "s:SV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SW11baseAddressSVSgvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SW11baseAddressSVSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "bindMemory",
           "printedName": "bindMemory(to:)",
-          "declKind": "Func",
-          "usr": "s:SW10bindMemory2toSRyxGxm_tlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeBufferPointer",
-              "printedName": "UnsafeBufferPointer<T>",
-              "usr": "s:SR",
+              "printedName": "UnsafeBufferPointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:SR"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_0_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SW10bindMemory2toSRyxGxm_tlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:SW16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -102412,10 +109391,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SW16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -102423,310 +109398,291 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SW16debugDescriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SW16debugDescriptionSSvp",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:SW",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "Collection",
+        "RandomAccessCollection",
+        "BidirectionalCollection",
+        "CustomDebugStringConvertible"
       ]
     },
     {
       "kind": "Function",
       "name": "withUnsafeMutableBytes",
       "printedName": "withUnsafeMutableBytes(of:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_1"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeFunc",
+          "name": "Function",
+          "printedName": "(UnsafeMutableRawBufferPointer) throws -> τ_0_1",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutableRawBufferPointer",
+              "printedName": "UnsafeMutableRawBufferPointer",
+              "usr": "s:Sw"
+            }
+          ],
+          "typeAttributes": [
+            "noescape"
+          ]
+        }
+      ],
       "declKind": "Func",
       "usr": "s:s22withUnsafeMutableBytes2of_q_xz_q_SwKXEtKr0_lF",
-      "location": "",
       "moduleName": "Swift",
-      "genericSig": "<T, Result>",
-      "throwing": true,
+      "genericSig": "<τ_0_0, τ_0_1>",
       "declAttributes": [
         "Rethrows",
         "Inlinable"
       ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "Result"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        },
-        {
-          "kind": "TypeFunc",
-          "name": "Function",
-          "printedName": "(UnsafeMutableRawBufferPointer) throws -> Result",
-          "typeAttributes": [
-            "noescape"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Result"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Paren",
-              "printedName": "(UnsafeMutableRawBufferPointer)",
-              "usr": "s:Sw",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafeMutableRawBufferPointer",
-                  "printedName": "UnsafeMutableRawBufferPointer",
-                  "usr": "s:Sw"
-                }
-              ]
-            }
-          ]
-        }
-      ]
+      "throwing": true
     },
     {
       "kind": "Function",
       "name": "withUnsafeBytes",
       "printedName": "withUnsafeBytes(of:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_1"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeFunc",
+          "name": "Function",
+          "printedName": "(UnsafeRawBufferPointer) throws -> τ_0_1",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeRawBufferPointer",
+              "printedName": "UnsafeRawBufferPointer",
+              "usr": "s:SW"
+            }
+          ],
+          "typeAttributes": [
+            "noescape"
+          ]
+        }
+      ],
       "declKind": "Func",
       "usr": "s:s15withUnsafeBytes2of_q_xz_q_SWKXEtKr0_lF",
-      "location": "",
       "moduleName": "Swift",
-      "genericSig": "<T, Result>",
-      "throwing": true,
+      "genericSig": "<τ_0_0, τ_0_1>",
       "declAttributes": [
         "Rethrows",
         "Inlinable"
       ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "Result"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        },
-        {
-          "kind": "TypeFunc",
-          "name": "Function",
-          "printedName": "(UnsafeRawBufferPointer) throws -> Result",
-          "typeAttributes": [
-            "noescape"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Result"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Paren",
-              "printedName": "(UnsafeRawBufferPointer)",
-              "usr": "s:SW",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafeRawBufferPointer",
-                  "printedName": "UnsafeRawBufferPointer",
-                  "usr": "s:SW"
-                }
-              ]
-            }
-          ]
-        }
-      ]
+      "throwing": true
     },
     {
       "kind": "Function",
       "name": "withUnsafeBytes",
       "printedName": "withUnsafeBytes(of:_:)",
-      "declKind": "Func",
-      "usr": "s:s15withUnsafeBytes2of_q_x_q_SWKXEtKr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, Result>",
-      "throwing": true,
-      "declAttributes": [
-        "Rethrows",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "Result"
+          "printedName": "τ_0_1"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "T"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeFunc",
           "name": "Function",
-          "printedName": "(UnsafeRawBufferPointer) throws -> Result",
-          "typeAttributes": [
-            "noescape"
-          ],
+          "printedName": "(UnsafeRawBufferPointer) throws -> τ_0_1",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Result"
+              "printedName": "τ_0_1"
             },
             {
               "kind": "TypeNominal",
-              "name": "Paren",
-              "printedName": "(UnsafeRawBufferPointer)",
-              "usr": "s:SW",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafeRawBufferPointer",
-                  "printedName": "UnsafeRawBufferPointer",
-                  "usr": "s:SW"
-                }
-              ]
+              "name": "UnsafeRawBufferPointer",
+              "printedName": "UnsafeRawBufferPointer",
+              "usr": "s:SW"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         }
-      ]
+      ],
+      "declKind": "Func",
+      "usr": "s:s15withUnsafeBytes2of_q_x_q_SWKXEtKr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1>",
+      "declAttributes": [
+        "Rethrows",
+        "Inlinable"
+      ],
+      "throwing": true
     },
     {
       "kind": "TypeDecl",
       "name": "UnsafePointer",
       "printedName": "UnsafePointer",
-      "declKind": "Struct",
-      "usr": "s:SP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Pointee>",
-      "conformingProtocols": [
-        "_Pointer",
-        "Hashable",
-        "Strideable",
-        "CustomDebugStringConvertible",
-        "CustomReflectable",
-        "Equatable",
-        "Comparable",
-        "_CustomPlaygroundQuickLookable",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "Distance",
-          "printedName": "Distance",
-          "declKind": "TypeAlias",
-          "usr": "s:SP8Distancea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
+          "kind": "Var",
+          "name": "_rawValue",
+          "printedName": "_rawValue",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "BuiltinRawPointer",
+              "printedName": "Builtin.RawPointer"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinRawPointer",
+                  "printedName": "Builtin.RawPointer"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SP9_rawValueBpvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SP9_rawValueBpvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Function",
           "name": "deallocate",
           "printedName": "deallocate()",
-          "declKind": "Func",
-          "usr": "s:SP10deallocateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SP10deallocateyyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "pointee",
           "printedName": "pointee",
-          "declKind": "Var",
-          "usr": "s:SP7pointeexvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Pointee"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SP7pointeexvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Pointee>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Pointee"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SP7pointeexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SP7pointeexvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "withMemoryRebound",
           "printedName": "withMemoryRebound(to:capacity:_:)",
-          "declKind": "Func",
-          "usr": "s:SP17withMemoryRebound2to8capacity_qd_0_qd__m_Siqd_0_SPyqd__GKXEtKr0_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee, T, Result>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Result"
+              "printedName": "τ_1_1"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_1_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
               ]
             },
@@ -102739,84 +109695,71 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(UnsafePointer<T>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(UnsafePointer<τ_1_0>) throws -> τ_1_1",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Result"
+                  "printedName": "τ_1_1"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafePointer<T>)",
-                  "usr": "s:SP",
+                  "name": "UnsafePointer",
+                  "printedName": "UnsafePointer<τ_1_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "UnsafePointer",
-                      "printedName": "UnsafePointer<T>",
-                      "usr": "s:SP",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "T"
-                        }
-                      ]
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_1_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SP17withMemoryRebound2to8capacity_qd_0_qd__m_Siqd_0_SPyqd__GKXEtKr0_lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0, τ_1_1>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
-          "kind": "TypeAlias",
-          "name": "Pointee",
-          "printedName": "Pointee",
-          "declKind": "TypeAlias",
-          "usr": "s:SP7Pointeea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Pointee"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:SP6Stridea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "children": [
+              "printedName": "τ_0_0"
+            },
             {
               "kind": "TypeNominal",
               "name": "Int",
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SPyxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SP9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -102828,11 +109771,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SP9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Pointee>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -102840,27 +109778,34 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SP9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SP9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:SP25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "PlaygroundQuickLook",
-              "printedName": "PlaygroundQuickLook",
+              "kind": "TypeNominal",
+              "name": "_PlaygroundQuickLook",
+              "printedName": "_PlaygroundQuickLook",
+              "usr": "s:s20_PlaygroundQuickLookO"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -102868,46 +109813,29 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
+              ],
               "declKind": "Accessor",
               "usr": "s:SP25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
               "moduleName": "Swift",
-              "genericSig": "<Pointee>",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "PlaygroundQuickLook",
-                  "printedName": "PlaygroundQuickLook",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "_PlaygroundQuickLook",
-                      "printedName": "_PlaygroundQuickLook",
-                      "usr": "s:s20_PlaygroundQuickLookO"
-                    }
-                  ]
-                }
-              ]
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SP25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "UnsafeMutablePointer",
-      "printedName": "UnsafeMutablePointer",
+      ],
       "declKind": "Struct",
-      "usr": "s:Sp",
-      "location": "",
+      "usr": "s:SP",
       "moduleName": "Swift",
-      "genericSig": "<Pointee>",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "_Pointer",
         "Hashable",
@@ -102918,174 +109846,164 @@
         "Comparable",
         "_CustomPlaygroundQuickLookable",
         "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "UnsafeMutablePointer",
+      "printedName": "UnsafeMutablePointer",
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "Distance",
-          "printedName": "Distance",
-          "declKind": "TypeAlias",
-          "usr": "s:Sp8Distancea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
+          "kind": "Var",
+          "name": "_rawValue",
+          "printedName": "_rawValue",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "BuiltinRawPointer",
+              "printedName": "Builtin.RawPointer"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinRawPointer",
+                  "printedName": "Builtin.RawPointer"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sp9_rawValueBpvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sp9_rawValueBpvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(mutating:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeMutablePointer",
+              "printedName": "UnsafeMutablePointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sp"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafePointer",
+              "printedName": "UnsafePointer<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:SP"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sp8mutatingSpyxGSPyxG_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(mutating:)",
-          "declKind": "Constructor",
-          "usr": "s:Sp8mutatingSpyxGSPyxG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UnsafeMutablePointer",
-              "printedName": "UnsafeMutablePointer<Pointee>",
-              "usr": "s:Sp",
+              "name": "Optional",
+              "printedName": "Optional<UnsafeMutablePointer<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Pointee"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafePointer",
-              "printedName": "UnsafePointer<UnsafeMutablePointer<Pointee>.Pointee>",
-              "usr": "s:SP",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Pointee",
-                  "printedName": "UnsafeMutablePointer<Pointee>.Pointee",
+                  "name": "UnsafeMutablePointer",
+                  "printedName": "UnsafeMutablePointer<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(mutating:)",
-          "declKind": "Constructor",
-          "usr": "s:Sp8mutatingSpyxGSgSPyxGSg_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UnsafeMutablePointer<Pointee>?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafeMutablePointer",
-                  "printedName": "UnsafeMutablePointer<Pointee>",
-                  "usr": "s:Sp",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Pointee"
-                    }
-                  ]
-                }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafePointer<UnsafeMutablePointer<Pointee>.Pointee>?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafePointer<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafePointer",
-                  "printedName": "UnsafePointer<UnsafeMutablePointer<Pointee>.Pointee>",
-                  "usr": "s:SP",
+                  "printedName": "UnsafePointer<τ_0_0>",
                   "children": [
                     {
-                      "kind": "TypeNameAlias",
-                      "name": "Pointee",
-                      "printedName": "UnsafeMutablePointer<Pointee>.Pointee",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_0"
-                        }
-                      ]
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sp8mutatingSpyxGSgSPyxGSg_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "allocate",
           "printedName": "allocate(capacity:)",
-          "declKind": "Func",
-          "usr": "s:Sp8allocate8capacitySpyxGSi_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
-              "printedName": "UnsafeMutablePointer<UnsafeMutablePointer<Pointee>.Pointee>",
-              "usr": "s:Sp",
+              "printedName": "UnsafeMutablePointer<τ_0_0>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Pointee",
-                  "printedName": "UnsafeMutablePointer<Pointee>.Pointee",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
@@ -103093,77 +110011,69 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp8allocate8capacitySpyxGSi_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "deallocate",
           "printedName": "deallocate()",
-          "declKind": "Func",
-          "usr": "s:Sp10deallocateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp10deallocateyyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "pointee",
           "printedName": "pointee",
-          "declKind": "Var",
-          "usr": "s:Sp7pointeexvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Pointee"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sp7pointeexvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Pointee>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Pointee"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sp7pointeexvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Setter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sp7pointeexvs",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Pointee>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -103173,24 +110083,30 @@
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Pointee"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sp7pointeexvs",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sp7pointeexvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "initialize",
           "printedName": "initialize(repeating:count:)",
-          "declKind": "Func",
-          "usr": "s:Sp10initialize9repeating5countyx_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103200,7 +110116,7 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Pointee"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -103208,20 +110124,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp10initialize9repeating5countyx_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "initialize",
           "printedName": "initialize(to:)",
-          "declKind": "Func",
-          "usr": "s:Sp10initialize2toyx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103231,49 +110146,40 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Pointee"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp10initialize2toyx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "move",
           "printedName": "move()",
-          "declKind": "Func",
-          "usr": "s:Sp4movexyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Pointee",
-              "printedName": "UnsafeMutablePointer<Pointee>.Pointee",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp4movexyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "assign",
           "printedName": "assign(repeating:count:)",
-          "declKind": "Func",
-          "usr": "s:Sp6assign9repeating5countyx_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103281,16 +110187,9 @@
               "printedName": "()"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Pointee",
-              "printedName": "UnsafeMutablePointer<Pointee>.Pointee",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -103298,20 +110197,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp6assign9repeating5countyx_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "assign",
           "printedName": "assign(from:count:)",
-          "declKind": "Func",
-          "usr": "s:Sp6assign4from5countySPyxG_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103321,22 +110219,15 @@
             {
               "kind": "TypeNominal",
               "name": "UnsafePointer",
-              "printedName": "UnsafePointer<UnsafeMutablePointer<Pointee>.Pointee>",
-              "usr": "s:SP",
+              "printedName": "UnsafePointer<τ_0_0>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Pointee",
-                  "printedName": "UnsafeMutablePointer<Pointee>.Pointee",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             },
             {
               "kind": "TypeNominal",
@@ -103344,20 +110235,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp6assign4from5countySPyxG_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "moveInitialize",
           "printedName": "moveInitialize(from:count:)",
-          "declKind": "Func",
-          "usr": "s:Sp14moveInitialize4from5countySpyxG_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103367,15 +110257,15 @@
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
-              "printedName": "UnsafeMutablePointer<Pointee>",
-              "usr": "s:Sp",
+              "printedName": "UnsafeMutablePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Pointee"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
@@ -103383,20 +110273,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp14moveInitialize4from5countySpyxG_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "initialize",
           "printedName": "initialize(from:count:)",
-          "declKind": "Func",
-          "usr": "s:Sp10initialize4from5countySPyxG_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103406,15 +110295,15 @@
             {
               "kind": "TypeNominal",
               "name": "UnsafePointer",
-              "printedName": "UnsafePointer<Pointee>",
-              "usr": "s:SP",
+              "printedName": "UnsafePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Pointee"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             },
             {
               "kind": "TypeNominal",
@@ -103422,20 +110311,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp10initialize4from5countySPyxG_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "moveAssign",
           "printedName": "moveAssign(from:count:)",
-          "declKind": "Func",
-          "usr": "s:Sp10moveAssign4from5countySpyxG_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103445,15 +110333,15 @@
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
-              "printedName": "UnsafeMutablePointer<Pointee>",
-              "usr": "s:Sp",
+              "printedName": "UnsafeMutablePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Pointee"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
@@ -103461,21 +110349,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp10moveAssign4from5countySpyxG_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "deinitialize",
           "printedName": "deinitialize(count:)",
-          "declKind": "Func",
-          "usr": "s:Sp12deinitialize5countSvSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103489,37 +110375,35 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp12deinitialize5countSvSi_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "withMemoryRebound",
           "printedName": "withMemoryRebound(to:capacity:_:)",
-          "declKind": "Func",
-          "usr": "s:Sp17withMemoryRebound2to8capacity_qd_0_qd__m_Siqd_0_Spyqd__GKXEtKr0_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee, T, Result>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Result"
+              "printedName": "τ_1_1"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_1_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
               ]
             },
@@ -103532,84 +110416,72 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(UnsafeMutablePointer<T>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(UnsafeMutablePointer<τ_1_0>) throws -> τ_1_1",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Result"
+                  "printedName": "τ_1_1"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeMutablePointer<T>)",
-                  "usr": "s:Sp",
+                  "name": "UnsafeMutablePointer",
+                  "printedName": "UnsafeMutablePointer<τ_1_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "UnsafeMutablePointer",
-                      "printedName": "UnsafeMutablePointer<T>",
-                      "usr": "s:Sp",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "T"
-                        }
-                      ]
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_1_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp17withMemoryRebound2to8capacity_qd_0_qd__m_Siqd_0_Spyqd__GKXEtKr0_lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0, τ_1_1>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:Sp6Stridea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
               "name": "Int",
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Pointee",
-          "printedName": "Pointee",
-          "declKind": "TypeAlias",
-          "usr": "s:Sp7Pointeea",
-          "location": "",
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SpyxSicip",
           "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Pointee"
-            }
-          ]
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Sp9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -103621,11 +110493,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sp9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Pointee>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -103633,22 +110500,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sp9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sp9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "initialize",
           "printedName": "initialize(to:count:)",
-          "declKind": "Func",
-          "usr": "s:Sp10initialize2to5countyx_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103658,7 +110526,7 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Pointee"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -103667,21 +110535,20 @@
               "hasDefaultArg": true,
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp10initialize2to5countyx_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "deinitialize",
           "printedName": "deinitialize()",
-          "declKind": "Func",
-          "usr": "s:Sp12deinitializeSvyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103689,20 +110556,21 @@
               "printedName": "UnsafeMutableRawPointer",
               "usr": "s:Sv"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp12deinitializeSvyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "deprecated": true,
+          "declAttributes": [
+            "DiscardableResult",
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "deallocate",
           "printedName": "deallocate(capacity:)",
-          "declKind": "Func",
-          "usr": "s:Sp10deallocate8capacityySi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103715,21 +110583,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp10deallocate8capacityySi_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "initialize",
           "printedName": "initialize(from:)",
-          "declKind": "Func",
-          "usr": "s:Sp10initialize4fromyqd___t7ElementQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee, C where Pointee == C.Element, C : Collection>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103739,27 +110606,33 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "C"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp10initialize4fromyqd___t7ElementQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : Collection>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:Sp25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "PlaygroundQuickLook",
-              "printedName": "PlaygroundQuickLook",
+              "kind": "TypeNominal",
+              "name": "_PlaygroundQuickLook",
+              "printedName": "_PlaygroundQuickLook",
+              "usr": "s:s20_PlaygroundQuickLookO"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -103767,88 +110640,87 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
+              ],
               "declKind": "Accessor",
               "usr": "s:Sp25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
               "moduleName": "Swift",
-              "genericSig": "<Pointee>",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "PlaygroundQuickLook",
-                  "printedName": "PlaygroundQuickLook",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "_PlaygroundQuickLook",
-                      "printedName": "_PlaygroundQuickLook",
-                      "usr": "s:s20_PlaygroundQuickLookO"
-                    }
-                  ]
-                }
-              ]
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sp25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:Sp",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "_Pointer",
+        "Hashable",
+        "Strideable",
+        "CustomDebugStringConvertible",
+        "CustomReflectable",
+        "Equatable",
+        "Comparable",
+        "_CustomPlaygroundQuickLookable",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnsafeRawPointer",
       "printedName": "UnsafeRawPointer",
-      "declKind": "Struct",
-      "usr": "s:SV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "_Pointer",
-        "Hashable",
-        "CustomDebugStringConvertible",
-        "CustomReflectable",
-        "Strideable",
-        "Comparable",
-        "Equatable",
-        "_CustomPlaygroundQuickLookable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "Pointee",
-          "printedName": "Pointee",
-          "declKind": "TypeAlias",
-          "usr": "s:SV7Pointeea",
-          "location": "",
-          "moduleName": "Swift",
+          "kind": "Var",
+          "name": "_rawValue",
+          "printedName": "_rawValue",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
+              "name": "BuiltinRawPointer",
+              "printedName": "Builtin.RawPointer"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinRawPointer",
+                  "printedName": "Builtin.RawPointer"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SV9_rawValueBpvg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SV9_rawValueBpvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SVySVSPyxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103859,36 +110731,34 @@
             {
               "kind": "TypeNominal",
               "name": "UnsafePointer",
-              "printedName": "UnsafePointer<T>",
-              "usr": "s:SP",
+              "printedName": "UnsafePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SVySVSPyxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SVySVSgSPyxGSgclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafeRawPointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafeRawPointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -103896,42 +110766,43 @@
                   "printedName": "UnsafeRawPointer",
                   "usr": "s:SV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafePointer<T>?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafePointer<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafePointer",
-                  "printedName": "UnsafePointer<T>",
-                  "usr": "s:SP",
+                  "printedName": "UnsafePointer<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "T"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SVySVSgSPyxGSgclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SVySVSvcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103945,25 +110816,23 @@
               "printedName": "UnsafeMutableRawPointer",
               "usr": "s:Sv"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SVySVSvcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SVySVSgSvSgcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafeRawPointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafeRawPointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -103971,13 +110840,13 @@
                   "printedName": "UnsafeRawPointer",
                   "usr": "s:SV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafeMutableRawPointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafeMutableRawPointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -103985,65 +110854,62 @@
                   "printedName": "UnsafeMutableRawPointer",
                   "usr": "s:Sv"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SVySVSgSvSgcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "deallocate",
           "printedName": "deallocate()",
-          "declKind": "Func",
-          "usr": "s:SV10deallocateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SV10deallocateyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "bindMemory",
           "printedName": "bindMemory(to:capacity:)",
-          "declKind": "Func",
-          "usr": "s:SV10bindMemory2to8capacitySPyxGxm_SitlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafePointer",
-              "printedName": "UnsafePointer<T>",
-              "usr": "s:SP",
+              "printedName": "UnsafePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_0_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
               ]
             },
@@ -104053,65 +110919,64 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SV10bindMemory2to8capacitySPyxGxm_SitlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "assumingMemoryBound",
           "printedName": "assumingMemoryBound(to:)",
-          "declKind": "Func",
-          "usr": "s:SV19assumingMemoryBound2toSPyxGxm_tlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafePointer",
-              "printedName": "UnsafePointer<T>",
-              "usr": "s:SP",
+              "printedName": "UnsafePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_0_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SV19assumingMemoryBound2toSPyxGxm_tlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "load",
           "printedName": "load(fromByteOffset:as:)",
-          "declKind": "Func",
-          "usr": "s:SV4load14fromByteOffset2asxSi_xmtlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -104123,25 +110988,28 @@
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_0_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SV4load14fromByteOffset2asxSi_xmtlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SV9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -104153,10 +111021,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SV9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -104164,22 +111028,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SV9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SV9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SVySVSAyxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104190,36 +111054,34 @@
             {
               "kind": "TypeNominal",
               "name": "AutoreleasingUnsafeMutablePointer",
-              "printedName": "AutoreleasingUnsafeMutablePointer<T>",
-              "usr": "s:SA",
+              "printedName": "AutoreleasingUnsafeMutablePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:SA"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SVySVSAyxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SVySVSgSAyxGSgclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafeRawPointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafeRawPointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -104227,42 +111089,43 @@
                   "printedName": "UnsafeRawPointer",
                   "usr": "s:SV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "AutoreleasingUnsafeMutablePointer<T>?",
-              "usr": "s:Sq",
+              "printedName": "Optional<AutoreleasingUnsafeMutablePointer<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AutoreleasingUnsafeMutablePointer",
-                  "printedName": "AutoreleasingUnsafeMutablePointer<T>",
-                  "usr": "s:SA",
+                  "printedName": "AutoreleasingUnsafeMutablePointer<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "T"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:SA"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SVySVSgSAyxGSgclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "advanced",
           "printedName": "advanced(by:)",
-          "declKind": "Func",
-          "usr": "s:SV8advanced2bySVSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104276,37 +111139,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:SV6Stridea",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:SV8advanced2bySVSi_tF",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:SV25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104318,10 +111162,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SV25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -104329,63 +111169,84 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SV25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SV25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:SV",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "_Pointer",
+        "Hashable",
+        "CustomDebugStringConvertible",
+        "CustomReflectable",
+        "Strideable",
+        "Comparable",
+        "Equatable",
+        "_CustomPlaygroundQuickLookable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnsafeMutableRawPointer",
       "printedName": "UnsafeMutableRawPointer",
-      "declKind": "Struct",
-      "usr": "s:Sv",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "_Pointer",
-        "Hashable",
-        "CustomDebugStringConvertible",
-        "CustomReflectable",
-        "Strideable",
-        "Comparable",
-        "Equatable",
-        "_CustomPlaygroundQuickLookable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "TypeAlias",
-          "name": "Pointee",
-          "printedName": "Pointee",
-          "declKind": "TypeAlias",
-          "usr": "s:Sv7Pointeea",
-          "location": "",
-          "moduleName": "Swift",
+          "kind": "Var",
+          "name": "_rawValue",
+          "printedName": "_rawValue",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
+              "name": "BuiltinRawPointer",
+              "printedName": "Builtin.RawPointer"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "BuiltinRawPointer",
+                  "printedName": "Builtin.RawPointer"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sv9_rawValueBpvg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sv9_rawValueBpvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SvySvSpyxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104396,36 +111257,34 @@
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
-              "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
+              "printedName": "UnsafeMutablePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SvySvSpyxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SvySvSgSpyxGSgclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafeMutableRawPointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafeMutableRawPointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -104433,42 +111292,43 @@
                   "printedName": "UnsafeMutableRawPointer",
                   "usr": "s:Sv"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafeMutablePointer<T>?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafeMutablePointer<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafeMutablePointer",
-                  "printedName": "UnsafeMutablePointer<T>",
-                  "usr": "s:Sp",
+                  "printedName": "UnsafeMutablePointer<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "T"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SvySvSgSpyxGSgclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(mutating:)",
-          "declKind": "Constructor",
-          "usr": "s:Sv8mutatingSvSV_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104482,25 +111342,23 @@
               "printedName": "UnsafeRawPointer",
               "usr": "s:SV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sv8mutatingSvSV_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(mutating:)",
-          "declKind": "Constructor",
-          "usr": "s:Sv8mutatingSvSgSVSg_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafeMutableRawPointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafeMutableRawPointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -104508,13 +111366,13 @@
                   "printedName": "UnsafeMutableRawPointer",
                   "usr": "s:Sv"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafeRawPointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafeRawPointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -104522,22 +111380,21 @@
                   "printedName": "UnsafeRawPointer",
                   "usr": "s:SV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sv8mutatingSvSgSVSg_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "allocate",
           "printedName": "allocate(byteCount:alignment:)",
-          "declKind": "Func",
-          "usr": "s:Sv8allocate9byteCount9alignmentSvSi_SitFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104557,63 +111414,60 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv8allocate9byteCount9alignmentSvSi_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "deallocate",
           "printedName": "deallocate()",
-          "declKind": "Func",
-          "usr": "s:Sv10deallocateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv10deallocateyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "bindMemory",
           "printedName": "bindMemory(to:capacity:)",
-          "declKind": "Func",
-          "usr": "s:Sv10bindMemory2to8capacitySpyxGxm_SitlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
-              "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
+              "printedName": "UnsafeMutablePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_0_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
               ]
             },
@@ -104623,91 +111477,89 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv10bindMemory2to8capacitySpyxGxm_SitlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "assumingMemoryBound",
           "printedName": "assumingMemoryBound(to:)",
-          "declKind": "Func",
-          "usr": "s:Sv19assumingMemoryBound2toSpyxGxm_tlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
-              "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
+              "printedName": "UnsafeMutablePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_0_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv19assumingMemoryBound2toSpyxGxm_tlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "initializeMemory",
           "printedName": "initializeMemory(as:repeating:count:)",
-          "declKind": "Func",
-          "usr": "s:Sv16initializeMemory2as9repeating5countSpyxGxm_xSitlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
-              "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
+              "printedName": "UnsafeMutablePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_0_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
               ]
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -104715,59 +111567,58 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv16initializeMemory2as9repeating5countSpyxGxm_xSitlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "initializeMemory",
           "printedName": "initializeMemory(as:from:count:)",
-          "declKind": "Func",
-          "usr": "s:Sv16initializeMemory2as4from5countSpyxGxm_SPyxGSitlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
-              "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
+              "printedName": "UnsafeMutablePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_0_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
               ]
             },
             {
               "kind": "TypeNominal",
               "name": "UnsafePointer",
-              "printedName": "UnsafePointer<T>",
-              "usr": "s:SP",
+              "printedName": "UnsafePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             },
             {
               "kind": "TypeNominal",
@@ -104775,59 +111626,58 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv16initializeMemory2as4from5countSpyxGxm_SPyxGSitlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "moveInitializeMemory",
           "printedName": "moveInitializeMemory(as:from:count:)",
-          "declKind": "Func",
-          "usr": "s:Sv20moveInitializeMemory2as4from5countSpyxGxm_AESitlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
-              "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
+              "printedName": "UnsafeMutablePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_0_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
               ]
             },
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
-              "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
+              "printedName": "UnsafeMutablePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
@@ -104835,25 +111685,25 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv20moveInitializeMemory2as4from5countSpyxGxm_AESitlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "load",
           "printedName": "load(fromByteOffset:as:)",
-          "declKind": "Func",
-          "usr": "s:Sv4load14fromByteOffset2asxSi_xmtlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -104865,29 +111715,28 @@
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_0_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv4load14fromByteOffset2asxSi_xmtlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "storeBytes",
           "printedName": "storeBytes(of:toByteOffset:as:)",
-          "declKind": "Func",
-          "usr": "s:Sv10storeBytes2of12toByteOffset2asyx_SixmtlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104897,7 +111746,7 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
@@ -104909,28 +111758,28 @@
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_0_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv10storeBytes2of12toByteOffset2asyx_SixmtlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "copyMemory",
           "printedName": "copyMemory(from:byteCount:)",
-          "declKind": "Func",
-          "usr": "s:Sv10copyMemory4from9byteCountySV_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104949,16 +111798,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv10copyMemory4from9byteCountySV_SitF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Sv9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -104970,10 +111821,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sv9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -104981,22 +111828,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sv9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sv9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SvySvSAyxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -105007,36 +111854,34 @@
             {
               "kind": "TypeNominal",
               "name": "AutoreleasingUnsafeMutablePointer",
-              "printedName": "AutoreleasingUnsafeMutablePointer<T>",
-              "usr": "s:SA",
+              "printedName": "AutoreleasingUnsafeMutablePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:SA"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SvySvSAyxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SvySvSgSAyxGSgclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "UnsafeMutableRawPointer?",
-              "usr": "s:Sq",
+              "printedName": "Optional<UnsafeMutableRawPointer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -105044,42 +111889,43 @@
                   "printedName": "UnsafeMutableRawPointer",
                   "usr": "s:Sv"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "AutoreleasingUnsafeMutablePointer<T>?",
-              "usr": "s:Sq",
+              "printedName": "Optional<AutoreleasingUnsafeMutablePointer<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AutoreleasingUnsafeMutablePointer",
-                  "printedName": "AutoreleasingUnsafeMutablePointer<T>",
-                  "usr": "s:SA",
+                  "printedName": "AutoreleasingUnsafeMutablePointer<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "T"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:SA"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SvySvSgSAyxGSgclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "advanced",
           "printedName": "advanced(by:)",
-          "declKind": "Func",
-          "usr": "s:Sv8advanced2bySvSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -105093,37 +111939,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stride",
-          "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:Sv6Stridea",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv8advanced2bySvSi_tF",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:Sv25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -105135,10 +111962,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sv25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -105146,22 +111969,24 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sv25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sv25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "allocate",
           "printedName": "allocate(bytes:alignedTo:)",
-          "declKind": "Func",
-          "usr": "s:Sv8allocate5bytes9alignedToSvSi_SitFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -105181,19 +112006,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv8allocate5bytes9alignedToSvSi_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "deallocate",
           "printedName": "deallocate(bytes:alignedTo:)",
-          "declKind": "Func",
-          "usr": "s:Sv10deallocate5bytes9alignedToySi_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -105212,19 +112038,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv10deallocate5bytes9alignedToySi_SitF",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "copyBytes",
           "printedName": "copyBytes(from:count:)",
-          "declKind": "Func",
-          "usr": "s:Sv9copyBytes4from5countySV_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -105243,44 +112069,42 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv9copyBytes4from5countySV_SitF",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "initializeMemory",
           "printedName": "initializeMemory(as:at:count:to:)",
-          "declKind": "Func",
-          "usr": "s:Sv16initializeMemory2as2at5count2toSpyxGxm_S2ixtlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
-              "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
+              "printedName": "UnsafeMutablePointer<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "T.Type",
+              "printedName": "τ_0_0.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_0_0"
                 }
               ]
             },
@@ -105301,82 +112125,92 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv16initializeMemory2as2at5count2toSpyxGxm_S2ixtlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "deprecated": true,
+          "declAttributes": [
+            "DiscardableResult",
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "initializeMemory",
           "printedName": "initializeMemory(as:from:)",
-          "declKind": "Func",
-          "usr": "s:Sv16initializeMemory2as4fromSpy7ElementQzGAEm_xtSlRzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<C where C : Collection>",
-          "deprecated": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
-              "printedName": "UnsafeMutablePointer<C.Element>",
-              "usr": "s:Sp",
+              "printedName": "UnsafeMutablePointer<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "C.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
               "name": "Metatype",
-              "printedName": "C.Element.Type",
+              "printedName": "τ_0_0.Element.Type",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "C.Element"
+                  "printedName": "τ_0_0.Element"
                 }
               ]
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "C"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv16initializeMemory2as4fromSpy7ElementQzGAEm_xtSlRzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Collection>",
+          "deprecated": true,
+          "declAttributes": [
+            "DiscardableResult",
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:Sv",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "_Pointer",
+        "Hashable",
+        "CustomDebugStringConvertible",
+        "CustomReflectable",
+        "Strideable",
+        "Comparable",
+        "Equatable",
+        "_CustomPlaygroundQuickLookable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnicodeDecodingResult",
       "printedName": "UnicodeDecodingResult",
-      "declKind": "Enum",
-      "usr": "s:s21UnicodeDecodingResultO",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Equatable"
-      ],
-      "declAttributes": [
-        "Frozen"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "scalarValue",
           "printedName": "scalarValue",
-          "declKind": "EnumElement",
-          "usr": "s:s21UnicodeDecodingResultO11scalarValueyABs0A0O6ScalarVcABmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -105396,52 +112230,37 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.Scalar)",
-                      "usr": "s:s7UnicodeO6ScalarV",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Scalar",
-                          "printedName": "Unicode.Scalar",
-                          "usr": "s:s7UnicodeO6ScalarV"
-                        }
-                      ]
+                      "name": "Scalar",
+                      "printedName": "Unicode.Scalar",
+                      "usr": "s:s7UnicodeO6ScalarV"
                     }
                   ]
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnicodeDecodingResult.Type)",
+                  "name": "Metatype",
+                  "printedName": "UnicodeDecodingResult.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "UnicodeDecodingResult.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "UnicodeDecodingResult",
-                          "printedName": "UnicodeDecodingResult",
-                          "usr": "s:s21UnicodeDecodingResultO"
-                        }
-                      ]
+                      "name": "UnicodeDecodingResult",
+                      "printedName": "UnicodeDecodingResult",
+                      "usr": "s:s21UnicodeDecodingResultO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s21UnicodeDecodingResultO11scalarValueyABs0A0O6ScalarVcABmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0
         },
         {
           "kind": "Var",
           "name": "emptyInput",
           "printedName": "emptyInput",
-          "declKind": "EnumElement",
-          "usr": "s:s21UnicodeDecodingResultO10emptyInputyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -105456,36 +112275,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnicodeDecodingResult.Type)",
+                  "name": "Metatype",
+                  "printedName": "UnicodeDecodingResult.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "UnicodeDecodingResult.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "UnicodeDecodingResult",
-                          "printedName": "UnicodeDecodingResult",
-                          "usr": "s:s21UnicodeDecodingResultO"
-                        }
-                      ]
+                      "name": "UnicodeDecodingResult",
+                      "printedName": "UnicodeDecodingResult",
+                      "usr": "s:s21UnicodeDecodingResultO"
                     }
                   ]
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s21UnicodeDecodingResultO10emptyInputyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1
         },
         {
           "kind": "Var",
           "name": "error",
           "printedName": "error",
-          "declKind": "EnumElement",
-          "usr": "s:s21UnicodeDecodingResultO5erroryA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -105500,70 +112312,94 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnicodeDecodingResult.Type)",
+                  "name": "Metatype",
+                  "printedName": "UnicodeDecodingResult.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Metatype",
-                      "printedName": "UnicodeDecodingResult.Type",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "UnicodeDecodingResult",
-                          "printedName": "UnicodeDecodingResult",
-                          "usr": "s:s21UnicodeDecodingResultO"
-                        }
-                      ]
+                      "name": "UnicodeDecodingResult",
+                      "printedName": "UnicodeDecodingResult",
+                      "usr": "s:s21UnicodeDecodingResultO"
                     }
                   ]
                 }
               ]
             }
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s21UnicodeDecodingResultO5erroryA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 2
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnicodeDecodingResult",
+              "printedName": "UnicodeDecodingResult",
+              "usr": "s:s21UnicodeDecodingResultO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnicodeDecodingResult",
+              "printedName": "UnicodeDecodingResult",
+              "usr": "s:s21UnicodeDecodingResultO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s21UnicodeDecodingResultO2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s21UnicodeDecodingResultO",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Frozen"
+      ],
+      "conformingProtocols": [
+        "Equatable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnicodeCodec",
       "printedName": "UnicodeCodec",
-      "declKind": "Protocol",
-      "usr": "s:s12UnicodeCodecP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : _UnicodeEncoding>",
-      "conformingProtocols": [
-        "_UnicodeEncoding"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s12UnicodeCodecPxycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnicodeCodec>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Self"
+              "printedName": "τ_0_0"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s12UnicodeCodecPxycfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnicodeCodec>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s12UnicodeCodecP6decodeys0A14DecodingResultOqd__zStRd__7ElementQyd__8CodeUnitRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, I where Self : UnicodeCodec, I : IteratorProtocol, Self.CodeUnit == I.Element>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -105574,20 +112410,20 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "I"
+              "printedName": "τ_1_0"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s12UnicodeCodecP6decodeys0A14DecodingResultOqd__zStRd__7ElementQyd__8CodeUnitRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 : UnicodeCodec, τ_1_0 : IteratorProtocol, τ_0_0.CodeUnit == τ_1_0.Element>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:into:)",
-          "declKind": "Func",
-          "usr": "s:s12UnicodeCodecP6encode_4intoys0A0O6ScalarV_y8CodeUnitQzXEtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnicodeCodec>",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -105603,54 +112439,44 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.CodeUnit) -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.CodeUnit) -> ()",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
+                  "kind": "TypeNominal",
                   "name": "Void",
-                  "printedName": "Void",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Void",
-                      "printedName": "()"
-                    }
-                  ]
+                  "printedName": "()"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.CodeUnit)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.CodeUnit"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.CodeUnit"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s12UnicodeCodecP6encode_4intoys0A0O6ScalarV_y8CodeUnitQzXEtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : UnicodeCodec>",
+          "static": true,
+          "protocolReq": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s12UnicodeCodecP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : _UnicodeEncoding>",
+      "conformingProtocols": [
+        "_UnicodeEncoding"
       ]
     },
     {
       "kind": "Function",
       "name": "transcode",
       "printedName": "transcode(_:from:to:stoppingOnError:into:)",
-      "declKind": "Func",
-      "usr": "s:s9transcode_4from2to15stoppingOnError4intoSbx_q_mq0_mSby8CodeUnitQy0_XEtStRzs16_UnicodeEncodingR_sAHR0_AFQy_7ElementRtzr1_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Input, InputEncoding, OutputEncoding where Input : IteratorProtocol, InputEncoding : _UnicodeEncoding, OutputEncoding : _UnicodeEncoding, Input.Element == InputEncoding.CodeUnit>",
-      "declAttributes": [
-        "Inline",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -105661,29 +112487,29 @@
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "Input"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "Metatype",
-          "printedName": "InputEncoding.Type",
+          "printedName": "τ_0_1.Type",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "InputEncoding"
+              "printedName": "τ_0_1"
             }
           ]
         },
         {
           "kind": "TypeNominal",
           "name": "Metatype",
-          "printedName": "OutputEncoding.Type",
+          "printedName": "τ_0_2.Type",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "OutputEncoding"
+              "printedName": "τ_0_2"
             }
           ]
         },
@@ -105696,197 +112522,100 @@
         {
           "kind": "TypeFunc",
           "name": "Function",
-          "printedName": "(OutputEncoding.CodeUnit) -> Void",
-          "typeAttributes": [
-            "noescape"
-          ],
+          "printedName": "(τ_0_2.CodeUnit) -> ()",
           "children": [
             {
-              "kind": "TypeNameAlias",
+              "kind": "TypeNominal",
               "name": "Void",
-              "printedName": "Void",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                }
-              ]
+              "printedName": "()"
             },
             {
               "kind": "TypeNominal",
-              "name": "Paren",
-              "printedName": "(OutputEncoding.CodeUnit)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "OutputEncoding.CodeUnit"
-                }
-              ]
+              "name": "DependentMember",
+              "printedName": "τ_0_2.CodeUnit"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s9transcode_4from2to15stoppingOnError4intoSbx_q_mq0_mSby8CodeUnitQy0_XEtStRzs16_UnicodeEncodingR_sAHR0_AFQy_7ElementRtzr1_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2 where τ_0_0 : IteratorProtocol, τ_0_1 : _UnicodeEncoding, τ_0_2 : _UnicodeEncoding, τ_0_0.Element == τ_0_1.CodeUnit>",
+      "declAttributes": [
+        "Inline",
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Unicode",
       "printedName": "Unicode",
-      "declKind": "Enum",
-      "usr": "s:s7UnicodeO",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Frozen"
-      ],
       "children": [
         {
           "kind": "TypeDecl",
           "name": "ASCII",
           "printedName": "ASCII",
-          "declKind": "Enum",
-          "usr": "s:s7UnicodeO5ASCIIO",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "_UnicodeEncoding"
-          ],
-          "declAttributes": [
-            "Frozen"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "CodeUnit",
-              "printedName": "CodeUnit",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5ASCIIO8CodeUnita",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt8",
-                  "printedName": "UInt8",
-                  "usr": "s:s5UInt8V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "EncodedScalar",
-              "printedName": "EncodedScalar",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5ASCIIO13EncodedScalara",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "CollectionOfOne",
-                  "printedName": "CollectionOfOne<Unicode.ASCII.CodeUnit>",
-                  "usr": "s:s15CollectionOfOneV",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "CodeUnit",
-                      "printedName": "Unicode.ASCII.CodeUnit",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "UInt8",
-                          "printedName": "UInt8",
-                          "usr": "s:s5UInt8V"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
               "kind": "Var",
               "name": "encodedReplacementCharacter",
               "printedName": "encodedReplacementCharacter",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO5ASCIIO27encodedReplacementCharacters15CollectionOfOneVys5UInt8VGvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "EncodedScalar",
-                  "printedName": "Unicode.ASCII.EncodedScalar",
+                  "kind": "TypeNominal",
+                  "name": "CollectionOfOne",
+                  "printedName": "CollectionOfOne<UInt8>",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "CollectionOfOne",
-                      "printedName": "CollectionOfOne<UInt8>",
-                      "usr": "s:s15CollectionOfOneV",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "UInt8",
-                          "printedName": "UInt8",
-                          "usr": "s:s5UInt8V"
-                        }
-                      ]
+                      "name": "UInt8",
+                      "printedName": "UInt8",
+                      "usr": "s:s5UInt8V"
                     }
-                  ]
+                  ],
+                  "usr": "s:s15CollectionOfOneV"
                 },
                 {
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO5ASCIIO27encodedReplacementCharacters15CollectionOfOneVys5UInt8VGvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
-                      "kind": "TypeNameAlias",
-                      "name": "EncodedScalar",
-                      "printedName": "Unicode.ASCII.EncodedScalar",
+                      "kind": "TypeNominal",
+                      "name": "CollectionOfOne",
+                      "printedName": "CollectionOfOne<UInt8>",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "CollectionOfOne",
-                          "printedName": "CollectionOfOne<UInt8>",
-                          "usr": "s:s15CollectionOfOneV",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt8",
-                              "printedName": "UInt8",
-                              "usr": "s:s5UInt8V"
-                            }
-                          ]
+                          "name": "UInt8",
+                          "printedName": "UInt8",
+                          "usr": "s:s5UInt8V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s15CollectionOfOneV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO5ASCIIO27encodedReplacementCharacters15CollectionOfOneVys5UInt8VGvgZ",
+                  "moduleName": "Swift",
+                  "static": true
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO5ASCIIO27encodedReplacementCharacters15CollectionOfOneVys5UInt8VGvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "decode",
               "printedName": "decode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5ASCIIO6decodeyAB6ScalarVs15CollectionOfOneVys5UInt8VGFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable",
-                "Inline"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -105895,15 +112624,43 @@
                   "usr": "s:s7UnicodeO6ScalarV"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "EncodedScalar",
-                  "printedName": "Unicode.ASCII.EncodedScalar",
+                  "kind": "TypeNominal",
+                  "name": "CollectionOfOne",
+                  "printedName": "CollectionOfOne<UInt8>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt8",
+                      "printedName": "UInt8",
+                      "usr": "s:s5UInt8V"
+                    }
+                  ],
+                  "usr": "s:s15CollectionOfOneV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5ASCIIO6decodeyAB6ScalarVs15CollectionOfOneVys5UInt8VGFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable",
+                "Inline"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "encode",
+              "printedName": "encode(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<CollectionOfOne<UInt8>>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "CollectionOfOne",
                       "printedName": "CollectionOfOne<UInt8>",
-                      "usr": "s:s15CollectionOfOneV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -105911,54 +112668,11 @@
                           "printedName": "UInt8",
                           "usr": "s:s5UInt8V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s15CollectionOfOneV"
                     }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "encode",
-              "printedName": "encode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5ASCIIO6encodeys15CollectionOfOneVys5UInt8VGSgAB6ScalarVFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable",
-                "Inline"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "Unicode.ASCII.EncodedScalar?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "EncodedScalar",
-                      "printedName": "Unicode.ASCII.EncodedScalar",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "CollectionOfOne",
-                          "printedName": "CollectionOfOne<UInt8>",
-                          "usr": "s:s15CollectionOfOneV",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt8",
-                              "printedName": "UInt8",
-                              "usr": "s:s5UInt8V"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -105966,97 +112680,80 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5ASCIIO6encodeys15CollectionOfOneVys5UInt8VGSgAB6ScalarVFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable",
+                "Inline"
               ]
             },
             {
               "kind": "Function",
               "name": "transcode",
               "printedName": "transcode(_:from:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5ASCIIO9transcode_4froms15CollectionOfOneVys5UInt8VGSg13EncodedScalarQz_xmts01_A8EncodingRzlFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<FromEncoding where FromEncoding : _UnicodeEncoding>",
-              "static": true,
-              "declAttributes": [
-                "Inlinable",
-                "Inline"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Unicode.ASCII.EncodedScalar?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<CollectionOfOne<UInt8>>",
                   "children": [
                     {
-                      "kind": "TypeNameAlias",
-                      "name": "EncodedScalar",
-                      "printedName": "Unicode.ASCII.EncodedScalar",
+                      "kind": "TypeNominal",
+                      "name": "CollectionOfOne",
+                      "printedName": "CollectionOfOne<UInt8>",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "CollectionOfOne",
-                          "printedName": "CollectionOfOne<UInt8>",
-                          "usr": "s:s15CollectionOfOneV",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt8",
-                              "printedName": "UInt8",
-                              "usr": "s:s5UInt8V"
-                            }
-                          ]
+                          "name": "UInt8",
+                          "printedName": "UInt8",
+                          "usr": "s:s5UInt8V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s15CollectionOfOneV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "FromEncoding.EncodedScalar"
+                  "printedName": "τ_0_0.EncodedScalar"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "Metatype",
-                  "printedName": "FromEncoding.Type",
+                  "printedName": "τ_0_0.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "FromEncoding"
+                      "printedName": "τ_0_0"
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5ASCIIO9transcode_4froms15CollectionOfOneVys5UInt8VGSg13EncodedScalarQz_xmts01_A8EncodingRzlFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : _UnicodeEncoding>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable",
+                "Inline"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "Parser",
               "printedName": "Parser",
-              "declKind": "Struct",
-              "usr": "s:s7UnicodeO5ASCIIO6ParserV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "_UnicodeParser"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
               "children": [
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init()",
-                  "declKind": "Constructor",
-                  "usr": "s:s7UnicodeO5ASCIIO6ParserVAFycfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106064,183 +112761,87 @@
                       "printedName": "Unicode.ASCII.Parser",
                       "usr": "s:s7UnicodeO5ASCIIO6ParserV"
                     }
-                  ]
-                },
-                {
-                  "kind": "TypeAlias",
-                  "name": "Encoding",
-                  "printedName": "Encoding",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO5ASCIIO6ParserV8Encodinga",
-                  "location": "",
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:s7UnicodeO5ASCIIO6ParserVAFycfc",
                   "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "ASCII",
-                      "printedName": "Unicode.ASCII",
-                      "usr": "s:s7UnicodeO5ASCIIO"
-                    }
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
                   "kind": "Function",
                   "name": "parseScalar",
                   "printedName": "parseScalar(from:)",
-                  "declKind": "Func",
-                  "usr": "s:s7UnicodeO5ASCIIO6ParserV11parseScalar4fromAB11ParseResultOy_s15CollectionOfOneVys5UInt8VGGxz_tStRzAN7ElementRtzlF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<I where I : IteratorProtocol, I.Element == Unicode.ASCII.Parser.Encoding.CodeUnit>",
-                  "mutating": true,
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "ParseResult",
-                      "printedName": "Unicode.ParseResult<Unicode.ASCII.Parser.Encoding.EncodedScalar>",
-                      "usr": "s:s7UnicodeO11ParseResultO",
+                      "printedName": "Unicode.ParseResult<CollectionOfOne<UInt8>>",
                       "children": [
                         {
-                          "kind": "TypeNameAlias",
-                          "name": "EncodedScalar",
-                          "printedName": "Unicode.ASCII.Parser.Encoding.EncodedScalar",
+                          "kind": "TypeNominal",
+                          "name": "CollectionOfOne",
+                          "printedName": "CollectionOfOne<UInt8>",
                           "children": [
                             {
                               "kind": "TypeNominal",
-                              "name": "CollectionOfOne",
-                              "printedName": "CollectionOfOne<UInt8>",
-                              "usr": "s:s15CollectionOfOneV",
-                              "children": [
-                                {
-                                  "kind": "TypeNominal",
-                                  "name": "UInt8",
-                                  "printedName": "UInt8",
-                                  "usr": "s:s5UInt8V"
-                                }
-                              ]
+                              "name": "UInt8",
+                              "printedName": "UInt8",
+                              "usr": "s:s5UInt8V"
                             }
-                          ]
+                          ],
+                          "usr": "s:s15CollectionOfOneV"
                         }
-                      ]
+                      ],
+                      "usr": "s:s7UnicodeO11ParseResultO"
                     },
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "I"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:s7UnicodeO5ASCIIO6ParserV11parseScalar4fromAB11ParseResultOy_s15CollectionOfOneVys5UInt8VGGxz_tStRzAN7ElementRtzlF",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : IteratorProtocol, τ_0_0.Element == UInt8>",
+                  "declAttributes": [
+                    "Inlinable"
+                  ],
+                  "mutating": true
                 }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "ForwardParser",
-              "printedName": "ForwardParser",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5ASCIIO13ForwardParsera",
-              "location": "",
+              ],
+              "declKind": "Struct",
+              "usr": "s:s7UnicodeO5ASCIIO6ParserV",
               "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Parser",
-                  "printedName": "Unicode.ASCII.Parser",
-                  "usr": "s:s7UnicodeO5ASCIIO6ParserV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "ReverseParser",
-              "printedName": "ReverseParser",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5ASCIIO13ReverseParsera",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Parser",
-                  "printedName": "Unicode.ASCII.Parser",
-                  "usr": "s:s7UnicodeO5ASCIIO6ParserV"
-                }
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "_UnicodeParser"
               ]
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Encoding",
-          "printedName": "Encoding",
-          "declKind": "TypeAlias",
-          "usr": "s:s7UnicodeO8Encodinga",
-          "location": "",
+          ],
+          "declKind": "Enum",
+          "usr": "s:s7UnicodeO5ASCIIO",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "_UnicodeEncoding",
-              "printedName": "_UnicodeEncoding",
-              "usr": "s:s16_UnicodeEncodingP"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Parser",
-          "printedName": "Parser",
-          "declKind": "TypeAlias",
-          "usr": "s:s7UnicodeO6Parsera",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "_UnicodeParser",
-              "printedName": "_UnicodeParser",
-              "usr": "s:s14_UnicodeParserP"
-            }
+          "declAttributes": [
+            "Frozen"
+          ],
+          "conformingProtocols": [
+            "_UnicodeEncoding"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Scalar",
           "printedName": "Scalar",
-          "declKind": "Struct",
-          "usr": "s:s7UnicodeO6ScalarV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "_ExpressibleByBuiltinUnicodeScalarLiteral",
-            "ExpressibleByUnicodeScalarLiteral",
-            "CustomStringConvertible",
-            "CustomDebugStringConvertible",
-            "LosslessStringConvertible",
-            "Hashable",
-            "Equatable",
-            "Comparable",
-            "CustomReflectable",
-            "_CustomPlaygroundQuickLookable",
-            "TextOutputStreamable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Var",
-              "name": "value",
-              "printedName": "value",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV5values6UInt32Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
+              "name": "_value",
+              "printedName": "_value",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106252,10 +112853,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV5values6UInt32Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106263,21 +112860,66 @@
                       "printedName": "UInt32",
                       "usr": "s:s6UInt32V"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV6_values6UInt32Vvg",
+                  "moduleName": "Swift",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV6_values6UInt32Vvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "value",
+              "printedName": "value",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt32",
+                  "printedName": "UInt32",
+                  "usr": "s:s6UInt32V"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt32",
+                      "printedName": "UInt32",
+                      "usr": "s:s6UInt32V"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV5values6UInt32Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV5values6UInt32Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(unicodeScalarLiteral:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO6ScalarV07unicodeB7LiteralA2D_tcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106291,25 +112933,23 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO6ScalarV07unicodeB7LiteralA2D_tcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO6ScalarVyADSgs6UInt32Vcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Unicode.Scalar?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<Unicode.Scalar>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106317,7 +112957,8 @@
                       "printedName": "Unicode.Scalar",
                       "usr": "s:s7UnicodeO6ScalarV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -106325,25 +112966,23 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO6ScalarVyADSgs6UInt32Vcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO6ScalarVyADSgs6UInt16Vcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Unicode.Scalar?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<Unicode.Scalar>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106351,7 +112990,8 @@
                       "printedName": "Unicode.Scalar",
                       "usr": "s:s7UnicodeO6ScalarV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -106359,19 +112999,18 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO6ScalarVyADSgs6UInt16Vcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO6ScalarVyADs5UInt8Vcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106385,19 +113024,18 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO6ScalarVyADs5UInt8Vcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO6ScalarVyA2Dcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106411,19 +113049,18 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO6ScalarVyA2Dcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "escaped",
               "printedName": "escaped(asASCII:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO6ScalarV7escaped7asASCIISSSb_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106437,19 +113074,18 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO6ScalarV7escaped7asASCIISSSb_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "isASCII",
               "printedName": "isASCII",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV7isASCIISbvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106461,10 +113097,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV7isASCIISbvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106472,38 +113104,23 @@
                       "printedName": "Bool",
                       "usr": "s:Sb"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV7isASCIISbvg",
+                  "moduleName": "Swift"
                 }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "UnicodeScalarLiteralType",
-              "printedName": "UnicodeScalarLiteralType",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO6ScalarV0aB11LiteralTypea",
-              "location": "",
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV7isASCIISbvp",
               "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Scalar",
-                  "printedName": "Unicode.Scalar",
-                  "usr": "s:s7UnicodeO6ScalarV"
-                }
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "description",
               "printedName": "description",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV11descriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106515,10 +113132,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV11descriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106526,18 +113139,23 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV11descriptionSSvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV11descriptionSSvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "debugDescription",
               "printedName": "debugDescription",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV16debugDescriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106549,10 +113167,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV16debugDescriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106560,27 +113174,25 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV16debugDescriptionSSvg",
+                  "moduleName": "Swift"
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV16debugDescriptionSSvp",
+              "moduleName": "Swift"
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO6ScalarVyADSgSScfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Unicode.Scalar?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<Unicode.Scalar>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106588,7 +113200,8 @@
                       "printedName": "Unicode.Scalar",
                       "usr": "s:s7UnicodeO6ScalarV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -106596,19 +113209,18 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO6ScalarVyADSgSScfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO6ScalarV4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106621,16 +113233,18 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO6ScalarV4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106642,10 +113256,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106653,27 +113263,27 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV9hashValueSivg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO6ScalarVyADSgSicfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Unicode.Scalar?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<Unicode.Scalar>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106681,7 +113291,8 @@
                       "printedName": "Unicode.Scalar",
                       "usr": "s:s7UnicodeO6ScalarV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -106689,37 +113300,87 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO6ScalarVyADSgSicfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Scalar",
+                  "printedName": "Unicode.Scalar",
+                  "usr": "s:s7UnicodeO6ScalarV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Scalar",
+                  "printedName": "Unicode.Scalar",
+                  "usr": "s:s7UnicodeO6ScalarV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO6ScalarV2eeoiySbAD_ADtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Scalar",
+                  "printedName": "Unicode.Scalar",
+                  "usr": "s:s7UnicodeO6ScalarV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Scalar",
+                  "printedName": "Unicode.Scalar",
+                  "usr": "s:s7UnicodeO6ScalarV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO6ScalarV1loiySbAD_ADtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "UTF16View",
               "printedName": "UTF16View",
-              "declKind": "Struct",
-              "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "RandomAccessCollection",
-                "BidirectionalCollection",
-                "Collection",
-                "Sequence"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
               "children": [
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init(value:)",
-                  "declKind": "Constructor",
-                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV5valueAfD_tcfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106733,44 +113394,62 @@
                       "printedName": "Unicode.Scalar",
                       "usr": "s:s7UnicodeO6ScalarV"
                     }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV5valueAfD_tcfc",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
-                  "kind": "TypeAlias",
-                  "name": "Indices",
-                  "printedName": "Indices",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV7Indicesa",
-                  "location": "",
-                  "moduleName": "Swift",
+                  "kind": "Var",
+                  "name": "value",
+                  "printedName": "value",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Range",
-                      "printedName": "Range<Int>",
-                      "usr": "s:Sn",
+                      "name": "Scalar",
+                      "printedName": "Unicode.Scalar",
+                      "usr": "s:s7UnicodeO6ScalarV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Int",
-                          "printedName": "Int",
-                          "usr": "s:Si"
+                          "name": "Scalar",
+                          "printedName": "Unicode.Scalar",
+                          "usr": "s:s7UnicodeO6ScalarV"
                         }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV5valueADvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "isInternal": true,
+                      "declAttributes": [
+                        "Transparent"
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV5valueADvp",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "UsableFromInline"
+                  ],
+                  "fixedbinaryorder": 0,
+                  "hasStorage": true
                 },
                 {
                   "kind": "Var",
                   "name": "startIndex",
                   "printedName": "startIndex",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV10startIndexSivp",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106782,10 +113461,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV10startIndexSivg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -106793,21 +113468,23 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV10startIndexSivg",
+                      "moduleName": "Swift"
                     }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV10startIndexSivp",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
                   "kind": "Var",
                   "name": "endIndex",
                   "printedName": "endIndex",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV8endIndexSivp",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106819,10 +113496,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV8endIndexSivg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -106830,114 +113503,62 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV8endIndexSivg",
+                      "moduleName": "Swift"
                     }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV8endIndexSivp",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
-                  "kind": "TypeAlias",
-                  "name": "Element",
-                  "printedName": "Element",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV7Elementa",
-                  "location": "",
-                  "moduleName": "Swift",
+                  "kind": "Subscript",
+                  "name": "subscript",
+                  "printedName": "subscript(_:)",
                   "children": [
                     {
-                      "kind": "TypeNameAlias",
-                      "name": "CodeUnit",
-                      "printedName": "UTF16.CodeUnit",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "UInt16",
-                          "printedName": "UInt16",
-                          "usr": "s:s6UInt16V"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeAlias",
-                  "name": "Index",
-                  "printedName": "Index",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV5Indexa",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
+                      "kind": "TypeNominal",
+                      "name": "UInt16",
+                      "printedName": "UInt16",
+                      "usr": "s:s6UInt16V"
+                    },
                     {
                       "kind": "TypeNominal",
                       "name": "Int",
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
-                },
-                {
-                  "kind": "TypeAlias",
-                  "name": "SubSequence",
-                  "printedName": "SubSequence",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV11SubSequencea",
-                  "location": "",
+                  ],
+                  "declKind": "Subscript",
+                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewVys6UInt16VSicip",
                   "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Slice",
-                      "printedName": "Slice<Unicode.Scalar.UTF16View>",
-                      "usr": "s:s5SliceV",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "UTF16View",
-                          "printedName": "Unicode.Scalar.UTF16View",
-                          "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeAlias",
-                  "name": "Iterator",
-                  "printedName": "Iterator",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV8Iteratora",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "IndexingIterator",
-                      "printedName": "IndexingIterator<Unicode.Scalar.UTF16View>",
-                      "usr": "s:s16IndexingIteratorV",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "UTF16View",
-                          "printedName": "Unicode.Scalar.UTF16View",
-                          "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV"
-                        }
-                      ]
-                    }
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 }
+              ],
+              "declKind": "Struct",
+              "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "RandomAccessCollection",
+                "BidirectionalCollection",
+                "Collection",
+                "Sequence"
               ]
             },
             {
               "kind": "Var",
               "name": "utf16",
               "printedName": "utf16",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV5utf16AD9UTF16ViewVvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106949,10 +113570,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV5utf16AD9UTF16ViewVvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106960,18 +113577,23 @@
                       "printedName": "Unicode.Scalar.UTF16View",
                       "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV5utf16AD9UTF16ViewVvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV5utf16AD9UTF16ViewVvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "customMirror",
               "printedName": "customMirror",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV12customMirrors0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106983,10 +113605,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV12customMirrors0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106994,23 +113612,20 @@
                       "printedName": "Mirror",
                       "usr": "s:s6MirrorV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV12customMirrors0D0Vvg",
+                  "moduleName": "Swift"
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV12customMirrors0D0Vvp",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "customPlaygroundQuickLook",
               "printedName": "customPlaygroundQuickLook",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV25customPlaygroundQuickLooks01_deF0Ovp",
-              "location": "",
-              "moduleName": "Swift",
-              "deprecated": true,
-              "declAttributes": [
-                "Available",
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -107022,10 +113637,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV25customPlaygroundQuickLooks01_deF0Ovg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107033,22 +113644,24 @@
                       "printedName": "_PlaygroundQuickLook",
                       "usr": "s:s20_PlaygroundQuickLookO"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV25customPlaygroundQuickLooks01_deF0Ovg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV25customPlaygroundQuickLooks01_deF0Ovp",
+              "moduleName": "Swift",
+              "deprecated": true,
+              "declAttributes": [
+                "Available"
               ]
             },
             {
               "kind": "Function",
               "name": "write",
               "printedName": "write(to:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO6ScalarV5write2toyxz_ts16TextOutputStreamRzlF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Target where Target : TextOutputStream>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -107058,27 +113671,26 @@
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Target"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO6ScalarV5write2toyxz_ts16TextOutputStreamRzlF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : TextOutputStream>",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "Properties",
               "printedName": "Properties",
-              "declKind": "Struct",
-              "usr": "s:s7UnicodeO6ScalarV10PropertiesV",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init(_:)",
-                  "declKind": "Constructor",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesVyAfDcfc",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107092,16 +113704,16 @@
                       "printedName": "Unicode.Scalar",
                       "usr": "s:s7UnicodeO6ScalarV"
                     }
-                  ]
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesVyAfDcfc",
+                  "moduleName": "Swift",
+                  "isInternal": true
                 },
                 {
                   "kind": "Var",
                   "name": "isAlphabetic",
                   "printedName": "isAlphabetic",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isAlphabeticSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107113,10 +113725,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isAlphabeticSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107124,18 +113732,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isAlphabeticSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isAlphabeticSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isASCIIHexDigit",
                   "printedName": "isASCIIHexDigit",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isASCIIHexDigitSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107147,10 +113757,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isASCIIHexDigitSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107158,18 +113764,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isASCIIHexDigitSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isASCIIHexDigitSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isBidiControl",
                   "printedName": "isBidiControl",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isBidiControlSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107181,10 +113789,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isBidiControlSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107192,18 +113796,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isBidiControlSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isBidiControlSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isBidiMirrored",
                   "printedName": "isBidiMirrored",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV14isBidiMirroredSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107215,10 +113821,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV14isBidiMirroredSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107226,18 +113828,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV14isBidiMirroredSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV14isBidiMirroredSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isDash",
                   "printedName": "isDash",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV6isDashSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107249,10 +113853,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV6isDashSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107260,18 +113860,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV6isDashSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV6isDashSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isDefaultIgnorableCodePoint",
                   "printedName": "isDefaultIgnorableCodePoint",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV27isDefaultIgnorableCodePointSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107283,10 +113885,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV27isDefaultIgnorableCodePointSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107294,18 +113892,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV27isDefaultIgnorableCodePointSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV27isDefaultIgnorableCodePointSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isDeprecated",
                   "printedName": "isDeprecated",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isDeprecatedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107317,10 +113917,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isDeprecatedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107328,18 +113924,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isDeprecatedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isDeprecatedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isDiacritic",
                   "printedName": "isDiacritic",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isDiacriticSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107351,10 +113949,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isDiacriticSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107362,18 +113956,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isDiacriticSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isDiacriticSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isExtender",
                   "printedName": "isExtender",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isExtenderSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107385,10 +113981,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isExtenderSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107396,18 +113988,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isExtenderSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isExtenderSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isFullCompositionExclusion",
                   "printedName": "isFullCompositionExclusion",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV26isFullCompositionExclusionSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107419,10 +114013,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV26isFullCompositionExclusionSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107430,18 +114020,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV26isFullCompositionExclusionSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV26isFullCompositionExclusionSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isGraphemeBase",
                   "printedName": "isGraphemeBase",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV14isGraphemeBaseSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107453,10 +114045,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV14isGraphemeBaseSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107464,18 +114052,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV14isGraphemeBaseSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV14isGraphemeBaseSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isGraphemeExtend",
                   "printedName": "isGraphemeExtend",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV16isGraphemeExtendSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107487,10 +114077,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV16isGraphemeExtendSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107498,18 +114084,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV16isGraphemeExtendSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV16isGraphemeExtendSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isHexDigit",
                   "printedName": "isHexDigit",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isHexDigitSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107521,10 +114109,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isHexDigitSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107532,18 +114116,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isHexDigitSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isHexDigitSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isIDContinue",
                   "printedName": "isIDContinue",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isIDContinueSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107555,10 +114141,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isIDContinueSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107566,18 +114148,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isIDContinueSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isIDContinueSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isIDStart",
                   "printedName": "isIDStart",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV9isIDStartSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107589,10 +114173,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV9isIDStartSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107600,18 +114180,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV9isIDStartSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV9isIDStartSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isIdeographic",
                   "printedName": "isIdeographic",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isIdeographicSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107623,10 +114205,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isIdeographicSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107634,18 +114212,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isIdeographicSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isIdeographicSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isIDSBinaryOperator",
                   "printedName": "isIDSBinaryOperator",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isIDSBinaryOperatorSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107657,10 +114237,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isIDSBinaryOperatorSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107668,18 +114244,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isIDSBinaryOperatorSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isIDSBinaryOperatorSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isIDSTrinaryOperator",
                   "printedName": "isIDSTrinaryOperator",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV20isIDSTrinaryOperatorSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107691,10 +114269,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV20isIDSTrinaryOperatorSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107702,18 +114276,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV20isIDSTrinaryOperatorSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV20isIDSTrinaryOperatorSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isJoinControl",
                   "printedName": "isJoinControl",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isJoinControlSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107725,10 +114301,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isJoinControlSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107736,18 +114308,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isJoinControlSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isJoinControlSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isLogicalOrderException",
                   "printedName": "isLogicalOrderException",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV23isLogicalOrderExceptionSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107759,10 +114333,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV23isLogicalOrderExceptionSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107770,18 +114340,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV23isLogicalOrderExceptionSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV23isLogicalOrderExceptionSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isLowercase",
                   "printedName": "isLowercase",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isLowercaseSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107793,10 +114365,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isLowercaseSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107804,18 +114372,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isLowercaseSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isLowercaseSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isMath",
                   "printedName": "isMath",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV6isMathSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107827,10 +114397,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV6isMathSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107838,18 +114404,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV6isMathSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV6isMathSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isNoncharacterCodePoint",
                   "printedName": "isNoncharacterCodePoint",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV23isNoncharacterCodePointSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107861,10 +114429,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV23isNoncharacterCodePointSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107872,18 +114436,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV23isNoncharacterCodePointSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV23isNoncharacterCodePointSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isQuotationMark",
                   "printedName": "isQuotationMark",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isQuotationMarkSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107895,10 +114461,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isQuotationMarkSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107906,18 +114468,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isQuotationMarkSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isQuotationMarkSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isRadical",
                   "printedName": "isRadical",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV9isRadicalSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107929,10 +114493,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV9isRadicalSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107940,18 +114500,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV9isRadicalSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV9isRadicalSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isSoftDotted",
                   "printedName": "isSoftDotted",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isSoftDottedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107963,10 +114525,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isSoftDottedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107974,18 +114532,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isSoftDottedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isSoftDottedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isTerminalPunctuation",
                   "printedName": "isTerminalPunctuation",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21isTerminalPunctuationSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107997,10 +114557,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21isTerminalPunctuationSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108008,18 +114564,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21isTerminalPunctuationSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21isTerminalPunctuationSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isUnifiedIdeograph",
                   "printedName": "isUnifiedIdeograph",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV18isUnifiedIdeographSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108031,10 +114589,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV18isUnifiedIdeographSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108042,18 +114596,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV18isUnifiedIdeographSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV18isUnifiedIdeographSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isUppercase",
                   "printedName": "isUppercase",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isUppercaseSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108065,10 +114621,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isUppercaseSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108076,18 +114628,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isUppercaseSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isUppercaseSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isWhitespace",
                   "printedName": "isWhitespace",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isWhitespaceSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108099,10 +114653,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isWhitespaceSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108110,18 +114660,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isWhitespaceSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isWhitespaceSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isXIDContinue",
                   "printedName": "isXIDContinue",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isXIDContinueSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108133,10 +114685,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isXIDContinueSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108144,18 +114692,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isXIDContinueSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isXIDContinueSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isXIDStart",
                   "printedName": "isXIDStart",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isXIDStartSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108167,10 +114717,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isXIDStartSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108178,18 +114724,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isXIDStartSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isXIDStartSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isSentenceTerminal",
                   "printedName": "isSentenceTerminal",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV18isSentenceTerminalSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108201,10 +114749,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV18isSentenceTerminalSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108212,18 +114756,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV18isSentenceTerminalSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV18isSentenceTerminalSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isVariationSelector",
                   "printedName": "isVariationSelector",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isVariationSelectorSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108235,10 +114781,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isVariationSelectorSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108246,18 +114788,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isVariationSelectorSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isVariationSelectorSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isPatternSyntax",
                   "printedName": "isPatternSyntax",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isPatternSyntaxSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108269,10 +114813,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isPatternSyntaxSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108280,18 +114820,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isPatternSyntaxSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isPatternSyntaxSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isPatternWhitespace",
                   "printedName": "isPatternWhitespace",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isPatternWhitespaceSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108303,10 +114845,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isPatternWhitespaceSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108314,18 +114852,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isPatternWhitespaceSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isPatternWhitespaceSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isCased",
                   "printedName": "isCased",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV7isCasedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108337,10 +114877,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV7isCasedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108348,18 +114884,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV7isCasedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV7isCasedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isCaseIgnorable",
                   "printedName": "isCaseIgnorable",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isCaseIgnorableSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108371,10 +114909,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isCaseIgnorableSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108382,18 +114916,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isCaseIgnorableSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isCaseIgnorableSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "changesWhenLowercased",
                   "printedName": "changesWhenLowercased",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenLowercasedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108405,10 +114941,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenLowercasedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108416,18 +114948,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenLowercasedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenLowercasedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "changesWhenUppercased",
                   "printedName": "changesWhenUppercased",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenUppercasedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108439,10 +114973,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenUppercasedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108450,18 +114980,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenUppercasedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenUppercasedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "changesWhenTitlecased",
                   "printedName": "changesWhenTitlecased",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenTitlecasedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108473,10 +115005,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenTitlecasedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108484,18 +115012,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenTitlecasedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenTitlecasedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "changesWhenCaseFolded",
                   "printedName": "changesWhenCaseFolded",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenCaseFoldedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108507,10 +115037,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenCaseFoldedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108518,18 +115044,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenCaseFoldedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenCaseFoldedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "changesWhenCaseMapped",
                   "printedName": "changesWhenCaseMapped",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenCaseMappedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108541,10 +115069,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenCaseMappedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108552,18 +115076,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenCaseMappedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenCaseMappedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "changesWhenNFKCCaseFolded",
                   "printedName": "changesWhenNFKCCaseFolded",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV25changesWhenNFKCCaseFoldedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108575,10 +115101,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV25changesWhenNFKCCaseFoldedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108586,18 +115108,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV25changesWhenNFKCCaseFoldedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV25changesWhenNFKCCaseFoldedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isEmoji",
                   "printedName": "isEmoji",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV7isEmojiSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108609,10 +115133,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV7isEmojiSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108620,18 +115140,26 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV7isEmojiSbvg",
+                      "moduleName": "Swift"
                     }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV7isEmojiSbvp",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Available",
+                    "Available",
+                    "Available",
+                    "Available"
                   ]
                 },
                 {
                   "kind": "Var",
                   "name": "isEmojiPresentation",
                   "printedName": "isEmojiPresentation",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isEmojiPresentationSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108643,10 +115171,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isEmojiPresentationSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108654,18 +115178,26 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isEmojiPresentationSbvg",
+                      "moduleName": "Swift"
                     }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isEmojiPresentationSbvp",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Available",
+                    "Available",
+                    "Available",
+                    "Available"
                   ]
                 },
                 {
                   "kind": "Var",
                   "name": "isEmojiModifier",
                   "printedName": "isEmojiModifier",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isEmojiModifierSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108677,10 +115209,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isEmojiModifierSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108688,18 +115216,26 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isEmojiModifierSbvg",
+                      "moduleName": "Swift"
                     }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isEmojiModifierSbvp",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Available",
+                    "Available",
+                    "Available",
+                    "Available"
                   ]
                 },
                 {
                   "kind": "Var",
                   "name": "isEmojiModifierBase",
                   "printedName": "isEmojiModifierBase",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isEmojiModifierBaseSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108711,10 +115247,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isEmojiModifierBaseSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108722,18 +115254,26 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isEmojiModifierBaseSbvg",
+                      "moduleName": "Swift"
                     }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isEmojiModifierBaseSbvp",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Available",
+                    "Available",
+                    "Available",
+                    "Available"
                   ]
                 },
                 {
                   "kind": "Var",
                   "name": "lowercaseMapping",
                   "printedName": "lowercaseMapping",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV16lowercaseMappingSSvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108745,10 +115285,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV16lowercaseMappingSSvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108756,18 +115292,20 @@
                           "printedName": "String",
                           "usr": "s:SS"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV16lowercaseMappingSSvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV16lowercaseMappingSSvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "titlecaseMapping",
                   "printedName": "titlecaseMapping",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV16titlecaseMappingSSvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108779,10 +115317,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV16titlecaseMappingSSvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108790,18 +115324,20 @@
                           "printedName": "String",
                           "usr": "s:SS"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV16titlecaseMappingSSvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV16titlecaseMappingSSvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "uppercaseMapping",
                   "printedName": "uppercaseMapping",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV16uppercaseMappingSSvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108813,10 +115349,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV16uppercaseMappingSSvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108824,29 +115356,57 @@
                           "printedName": "String",
                           "usr": "s:SS"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV16uppercaseMappingSSvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV16uppercaseMappingSSvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "age",
                   "printedName": "age",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV3ageSi5major_Si5minortSgvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
-                      "printedName": "Unicode.Version?",
-                      "usr": "s:Sq",
+                      "printedName": "Optional<(major: Int, minor: Int)>",
                       "children": [
                         {
-                          "kind": "TypeNameAlias",
-                          "name": "Version",
-                          "printedName": "Unicode.Version",
+                          "kind": "TypeNominal",
+                          "name": "Tuple",
+                          "printedName": "(major: Int, minor: Int)",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "Int",
+                              "printedName": "Int",
+                              "usr": "s:Si"
+                            },
+                            {
+                              "kind": "TypeNominal",
+                              "name": "Int",
+                              "printedName": "Int",
+                              "usr": "s:Si"
+                            }
+                          ]
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Optional",
+                          "printedName": "Optional<(major: Int, minor: Int)>",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -108867,65 +115427,23 @@
                                 }
                               ]
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         }
-                      ]
-                    },
-                    {
-                      "kind": "Getter",
-                      "name": "_",
-                      "printedName": "_()",
+                      ],
                       "declKind": "Accessor",
                       "usr": "s:s7UnicodeO6ScalarV10PropertiesV3ageSi5major_Si5minortSgvg",
-                      "location": "",
-                      "moduleName": "Swift",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Optional",
-                          "printedName": "Unicode.Version?",
-                          "usr": "s:Sq",
-                          "children": [
-                            {
-                              "kind": "TypeNameAlias",
-                              "name": "Version",
-                              "printedName": "Unicode.Version",
-                              "children": [
-                                {
-                                  "kind": "TypeNominal",
-                                  "name": "Tuple",
-                                  "printedName": "(major: Int, minor: Int)",
-                                  "children": [
-                                    {
-                                      "kind": "TypeNominal",
-                                      "name": "Int",
-                                      "printedName": "Int",
-                                      "usr": "s:Si"
-                                    },
-                                    {
-                                      "kind": "TypeNominal",
-                                      "name": "Int",
-                                      "printedName": "Int",
-                                      "usr": "s:Si"
-                                    }
-                                  ]
-                                }
-                              ]
-                            }
-                          ]
-                        }
-                      ]
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV3ageSi5major_Si5minortSgvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "generalCategory",
                   "printedName": "generalCategory",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15generalCategoryAB07GeneralE0Ovp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108937,10 +115455,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15generalCategoryAB07GeneralE0Ovg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108948,24 +115462,25 @@
                           "printedName": "Unicode.GeneralCategory",
                           "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15generalCategoryAB07GeneralE0Ovg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15generalCategoryAB07GeneralE0Ovp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "name",
                   "printedName": "name",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV4nameSSSgvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
-                      "printedName": "String?",
-                      "usr": "s:Sq",
+                      "printedName": "Optional<String>",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108973,22 +115488,18 @@
                           "printedName": "String",
                           "usr": "s:SS"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     },
                     {
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV4nameSSSgvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "Optional",
-                          "printedName": "String?",
-                          "usr": "s:Sq",
+                          "printedName": "Optional<String>",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -108996,26 +115507,28 @@
                               "printedName": "String",
                               "usr": "s:SS"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV4nameSSSgvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV4nameSSSgvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "nameAlias",
                   "printedName": "nameAlias",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV9nameAliasSSSgvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
-                      "printedName": "String?",
-                      "usr": "s:Sq",
+                      "printedName": "Optional<String>",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -109023,22 +115536,18 @@
                           "printedName": "String",
                           "usr": "s:SS"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     },
                     {
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV9nameAliasSSSgvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "Optional",
-                          "printedName": "String?",
-                          "usr": "s:Sq",
+                          "printedName": "Optional<String>",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -109046,20 +115555,23 @@
                               "printedName": "String",
                               "usr": "s:SS"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV9nameAliasSSSgvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV9nameAliasSSSgvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "canonicalCombiningClass",
                   "printedName": "canonicalCombiningClass",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV23canonicalCombiningClassAB09CanonicaleF0Vvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -109071,10 +115583,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV23canonicalCombiningClassAB09CanonicaleF0Vvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -109082,24 +115590,25 @@
                           "printedName": "Unicode.CanonicalCombiningClass",
                           "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV23canonicalCombiningClassAB09CanonicaleF0Vvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV23canonicalCombiningClassAB09CanonicaleF0Vvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "numericType",
                   "printedName": "numericType",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV11numericTypeAB07NumericE0OSgvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
-                      "printedName": "Unicode.NumericType?",
-                      "usr": "s:Sq",
+                      "printedName": "Optional<Unicode.NumericType>",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -109107,22 +115616,18 @@
                           "printedName": "Unicode.NumericType",
                           "usr": "s:s7UnicodeO11NumericTypeO"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     },
                     {
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV11numericTypeAB07NumericE0OSgvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "Optional",
-                          "printedName": "Unicode.NumericType?",
-                          "usr": "s:Sq",
+                          "printedName": "Optional<Unicode.NumericType>",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -109130,26 +115635,28 @@
                               "printedName": "Unicode.NumericType",
                               "usr": "s:s7UnicodeO11NumericTypeO"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV11numericTypeAB07NumericE0OSgvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV11numericTypeAB07NumericE0OSgvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "numericValue",
                   "printedName": "numericValue",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12numericValueSdSgvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
-                      "printedName": "Double?",
-                      "usr": "s:Sq",
+                      "printedName": "Optional<Double>",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -109157,22 +115664,18 @@
                           "printedName": "Double",
                           "usr": "s:Sd"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     },
                     {
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12numericValueSdSgvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "Optional",
-                          "printedName": "Double?",
-                          "usr": "s:Sq",
+                          "printedName": "Optional<Double>",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -109180,22 +115683,28 @@
                               "printedName": "Double",
                               "usr": "s:Sd"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12numericValueSdSgvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12numericValueSdSgvp",
+                  "moduleName": "Swift"
                 }
-              ]
+              ],
+              "declKind": "Struct",
+              "usr": "s:s7UnicodeO6ScalarV10PropertiesV",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "properties",
               "printedName": "properties",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV10propertiesAD10PropertiesVvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -109207,10 +115716,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV10propertiesAD10PropertiesVvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -109218,59 +115723,101 @@
                       "printedName": "Unicode.Scalar.Properties",
                       "usr": "s:s7UnicodeO6ScalarV10PropertiesV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV10propertiesAD10PropertiesVvg",
+                  "moduleName": "Swift"
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV10propertiesAD10PropertiesVvp",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s7UnicodeO6ScalarV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "_ExpressibleByBuiltinUnicodeScalarLiteral",
+            "ExpressibleByUnicodeScalarLiteral",
+            "CustomStringConvertible",
+            "CustomDebugStringConvertible",
+            "LosslessStringConvertible",
+            "Hashable",
+            "Equatable",
+            "Comparable",
+            "CustomReflectable",
+            "_CustomPlaygroundQuickLookable",
+            "TextOutputStreamable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "UTF16",
           "printedName": "UTF16",
-          "declKind": "Enum",
-          "usr": "s:s7UnicodeO5UTF16O",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "_UnicodeEncoding",
-            "UnicodeCodec"
-          ],
-          "declAttributes": [
-            "Frozen"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "CodeUnit",
-              "printedName": "CodeUnit",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5UTF16O8CodeUnita",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Var",
+              "name": "_swift3Buffer",
+              "printedName": "_swift3Buffer",
               "children": [
                 {
-                  "kind": "TypeNominal",
-                  "name": "UInt16",
-                  "printedName": "UInt16",
-                  "usr": "s:s6UInt16V"
+                  "kind": "TypeFunc",
+                  "name": "Function",
+                  "printedName": "(Unicode.UTF16.Type) -> (Unicode.UTF16.ForwardParser) -> Unicode.UTF16",
+                  "children": [
+                    {
+                      "kind": "TypeFunc",
+                      "name": "Function",
+                      "printedName": "(Unicode.UTF16.ForwardParser) -> Unicode.UTF16",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UTF16",
+                          "printedName": "Unicode.UTF16",
+                          "usr": "s:s7UnicodeO5UTF16O"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "ForwardParser",
+                          "printedName": "Unicode.UTF16.ForwardParser",
+                          "usr": "s:s7UnicodeO5UTF16O13ForwardParserV"
+                        }
+                      ]
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Metatype",
+                      "printedName": "Unicode.UTF16.Type",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UTF16",
+                          "printedName": "Unicode.UTF16",
+                          "usr": "s:s7UnicodeO5UTF16O"
+                        }
+                      ]
+                    }
+                  ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO5UTF16O13_swift3BufferyA2D13ForwardParserVcADmF",
+              "moduleName": "Swift",
+              "fixedbinaryorder": 0
             },
             {
-              "kind": "TypeAlias",
-              "name": "EncodedScalar",
-              "printedName": "EncodedScalar",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5UTF16O13EncodedScalara",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Var",
+              "name": "encodedReplacementCharacter",
+              "printedName": "encodedReplacementCharacter",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "_UIntBuffer",
                   "printedName": "_UIntBuffer<UInt32, UInt16>",
-                  "usr": "s:s11_UIntBufferV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -109284,33 +115831,18 @@
                       "printedName": "UInt16",
                       "usr": "s:s6UInt16V"
                     }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "encodedReplacementCharacter",
-              "printedName": "encodedReplacementCharacter",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO5UTF16O27encodedReplacementCharacters11_UIntBufferVys6UInt32Vs6UInt16VGvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
+                  ],
+                  "usr": "s:s11_UIntBufferV"
+                },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "EncodedScalar",
-                  "printedName": "Unicode.UTF16.EncodedScalar",
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "_UIntBuffer",
                       "printedName": "_UIntBuffer<UInt32, UInt16>",
-                      "usr": "s:s11_UIntBufferV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -109324,63 +115856,28 @@
                           "printedName": "UInt16",
                           "usr": "s:s6UInt16V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s11_UIntBufferV"
                     }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
+                  ],
                   "declKind": "Accessor",
                   "usr": "s:s7UnicodeO5UTF16O27encodedReplacementCharacters11_UIntBufferVys6UInt32Vs6UInt16VGvgZ",
-                  "location": "",
                   "moduleName": "Swift",
-                  "static": true,
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "EncodedScalar",
-                      "printedName": "Unicode.UTF16.EncodedScalar",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "_UIntBuffer",
-                          "printedName": "_UIntBuffer<UInt32, UInt16>",
-                          "usr": "s:s11_UIntBufferV",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt32",
-                              "printedName": "UInt32",
-                              "usr": "s:s6UInt32V"
-                            },
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt16",
-                              "printedName": "UInt16",
-                              "usr": "s:s6UInt16V"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  "static": true
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO5UTF16O27encodedReplacementCharacters11_UIntBufferVys6UInt32Vs6UInt16VGvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "decode",
               "printedName": "decode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O6decodeyAB6ScalarVs11_UIntBufferVys6UInt32Vs6UInt16VGFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -109389,15 +115886,48 @@
                   "usr": "s:s7UnicodeO6ScalarV"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "EncodedScalar",
-                  "printedName": "Unicode.UTF16.EncodedScalar",
+                  "kind": "TypeNominal",
+                  "name": "_UIntBuffer",
+                  "printedName": "_UIntBuffer<UInt32, UInt16>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt32",
+                      "printedName": "UInt32",
+                      "usr": "s:s6UInt32V"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt16",
+                      "printedName": "UInt16",
+                      "usr": "s:s6UInt16V"
+                    }
+                  ],
+                  "usr": "s:s11_UIntBufferV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O6decodeyAB6ScalarVs11_UIntBufferVys6UInt32Vs6UInt16VGFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "encode",
+              "printedName": "encode(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<_UIntBuffer<UInt32, UInt16>>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "_UIntBuffer",
                       "printedName": "_UIntBuffer<UInt32, UInt16>",
-                      "usr": "s:s11_UIntBufferV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -109411,59 +115941,11 @@
                           "printedName": "UInt16",
                           "usr": "s:s6UInt16V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s11_UIntBufferV"
                     }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "encode",
-              "printedName": "encode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O6encodeys11_UIntBufferVys6UInt32Vs6UInt16VGSgAB6ScalarVFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "Unicode.UTF16.EncodedScalar?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "EncodedScalar",
-                      "printedName": "Unicode.UTF16.EncodedScalar",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "_UIntBuffer",
-                          "printedName": "_UIntBuffer<UInt32, UInt16>",
-                          "usr": "s:s11_UIntBufferV",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt32",
-                              "printedName": "UInt32",
-                              "usr": "s:s6UInt32V"
-                            },
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt16",
-                              "printedName": "UInt16",
-                              "usr": "s:s6UInt16V"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -109471,104 +115953,85 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O6encodeys11_UIntBufferVys6UInt32Vs6UInt16VGSgAB6ScalarVFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "transcode",
               "printedName": "transcode(_:from:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O9transcode_4froms11_UIntBufferVys6UInt32Vs6UInt16VGSg13EncodedScalarQz_xmts01_A8EncodingRzlFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<FromEncoding where FromEncoding : _UnicodeEncoding>",
-              "static": true,
-              "declAttributes": [
-                "Inline",
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Unicode.UTF16.EncodedScalar?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<_UIntBuffer<UInt32, UInt16>>",
                   "children": [
                     {
-                      "kind": "TypeNameAlias",
-                      "name": "EncodedScalar",
-                      "printedName": "Unicode.UTF16.EncodedScalar",
+                      "kind": "TypeNominal",
+                      "name": "_UIntBuffer",
+                      "printedName": "_UIntBuffer<UInt32, UInt16>",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "_UIntBuffer",
-                          "printedName": "_UIntBuffer<UInt32, UInt16>",
-                          "usr": "s:s11_UIntBufferV",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt32",
-                              "printedName": "UInt32",
-                              "usr": "s:s6UInt32V"
-                            },
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt16",
-                              "printedName": "UInt16",
-                              "usr": "s:s6UInt16V"
-                            }
-                          ]
+                          "name": "UInt32",
+                          "printedName": "UInt32",
+                          "usr": "s:s6UInt32V"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UInt16",
+                          "printedName": "UInt16",
+                          "usr": "s:s6UInt16V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s11_UIntBufferV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "FromEncoding.EncodedScalar"
+                  "printedName": "τ_0_0.EncodedScalar"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "Metatype",
-                  "printedName": "FromEncoding.Type",
+                  "printedName": "τ_0_0.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "FromEncoding"
+                      "printedName": "τ_0_0"
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O9transcode_4froms11_UIntBufferVys6UInt32Vs6UInt16VGSg13EncodedScalarQz_xmts01_A8EncodingRzlFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : _UnicodeEncoding>",
+              "static": true,
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "ForwardParser",
               "printedName": "ForwardParser",
-              "declKind": "Struct",
-              "usr": "s:s7UnicodeO5UTF16O13ForwardParserV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "_UnicodeParser",
-                "_UTFParser"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
               "children": [
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init()",
-                  "declKind": "Constructor",
-                  "usr": "s:s7UnicodeO5UTF16O13ForwardParserVAFycfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -109576,54 +116039,141 @@
                       "printedName": "Unicode.UTF16.ForwardParser",
                       "usr": "s:s7UnicodeO5UTF16O13ForwardParserV"
                     }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:s7UnicodeO5UTF16O13ForwardParserVAFycfc",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
-                  "kind": "TypeAlias",
-                  "name": "Encoding",
-                  "printedName": "Encoding",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO5UTF16O13ForwardParserV8Encodinga",
-                  "location": "",
-                  "moduleName": "Swift",
+                  "kind": "Var",
+                  "name": "_buffer",
+                  "printedName": "_buffer",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "UTF16",
-                      "printedName": "Unicode.UTF16",
-                      "usr": "s:s7UnicodeO5UTF16O"
+                      "name": "_UIntBuffer",
+                      "printedName": "_UIntBuffer<UInt32, UInt16>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UInt32",
+                          "printedName": "UInt32",
+                          "usr": "s:s6UInt32V"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UInt16",
+                          "printedName": "UInt16",
+                          "usr": "s:s6UInt16V"
+                        }
+                      ],
+                      "usr": "s:s11_UIntBufferV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "_UIntBuffer",
+                          "printedName": "_UIntBuffer<UInt32, UInt16>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt32",
+                              "printedName": "UInt32",
+                              "usr": "s:s6UInt32V"
+                            },
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt16",
+                              "printedName": "UInt16",
+                              "usr": "s:s6UInt16V"
+                            }
+                          ],
+                          "usr": "s:s11_UIntBufferV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO5UTF16O13ForwardParserV7_buffers11_UIntBufferVys6UInt32Vs6UInt16VGvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    },
+                    {
+                      "kind": "Setter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Void",
+                          "printedName": "()"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "_UIntBuffer",
+                          "printedName": "_UIntBuffer<UInt32, UInt16>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt32",
+                              "printedName": "UInt32",
+                              "usr": "s:s6UInt32V"
+                            },
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt16",
+                              "printedName": "UInt16",
+                              "usr": "s:s6UInt16V"
+                            }
+                          ],
+                          "usr": "s:s11_UIntBufferV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO5UTF16O13ForwardParserV7_buffers11_UIntBufferVys6UInt32Vs6UInt16VGvs",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ],
+                      "mutating": true
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO5UTF16O13ForwardParserV7_buffers11_UIntBufferVys6UInt32Vs6UInt16VGvp",
+                  "moduleName": "Swift",
+                  "fixedbinaryorder": 0,
+                  "hasStorage": true
                 }
+              ],
+              "declKind": "Struct",
+              "usr": "s:s7UnicodeO5UTF16O13ForwardParserV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "_UnicodeParser",
+                "_UTFParser"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "ReverseParser",
               "printedName": "ReverseParser",
-              "declKind": "Struct",
-              "usr": "s:s7UnicodeO5UTF16O13ReverseParserV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "_UnicodeParser",
-                "_UTFParser"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
               "children": [
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init()",
-                  "declKind": "Constructor",
-                  "usr": "s:s7UnicodeO5UTF16O13ReverseParserVAFycfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -109631,38 +116181,136 @@
                       "printedName": "Unicode.UTF16.ReverseParser",
                       "usr": "s:s7UnicodeO5UTF16O13ReverseParserV"
                     }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:s7UnicodeO5UTF16O13ReverseParserVAFycfc",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
-                  "kind": "TypeAlias",
-                  "name": "Encoding",
-                  "printedName": "Encoding",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO5UTF16O13ReverseParserV8Encodinga",
-                  "location": "",
-                  "moduleName": "Swift",
+                  "kind": "Var",
+                  "name": "_buffer",
+                  "printedName": "_buffer",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "UTF16",
-                      "printedName": "Unicode.UTF16",
-                      "usr": "s:s7UnicodeO5UTF16O"
+                      "name": "_UIntBuffer",
+                      "printedName": "_UIntBuffer<UInt32, UInt16>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UInt32",
+                          "printedName": "UInt32",
+                          "usr": "s:s6UInt32V"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UInt16",
+                          "printedName": "UInt16",
+                          "usr": "s:s6UInt16V"
+                        }
+                      ],
+                      "usr": "s:s11_UIntBufferV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "_UIntBuffer",
+                          "printedName": "_UIntBuffer<UInt32, UInt16>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt32",
+                              "printedName": "UInt32",
+                              "usr": "s:s6UInt32V"
+                            },
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt16",
+                              "printedName": "UInt16",
+                              "usr": "s:s6UInt16V"
+                            }
+                          ],
+                          "usr": "s:s11_UIntBufferV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO5UTF16O13ReverseParserV7_buffers11_UIntBufferVys6UInt32Vs6UInt16VGvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    },
+                    {
+                      "kind": "Setter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Void",
+                          "printedName": "()"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "_UIntBuffer",
+                          "printedName": "_UIntBuffer<UInt32, UInt16>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt32",
+                              "printedName": "UInt32",
+                              "usr": "s:s6UInt32V"
+                            },
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt16",
+                              "printedName": "UInt16",
+                              "usr": "s:s6UInt16V"
+                            }
+                          ],
+                          "usr": "s:s11_UIntBufferV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO5UTF16O13ReverseParserV7_buffers11_UIntBufferVys6UInt32Vs6UInt16VGvs",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ],
+                      "mutating": true
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO5UTF16O13ReverseParserV7_buffers11_UIntBufferVys6UInt32Vs6UInt16VGvp",
+                  "moduleName": "Swift",
+                  "fixedbinaryorder": 0,
+                  "hasStorage": true
                 }
+              ],
+              "declKind": "Struct",
+              "usr": "s:s7UnicodeO5UTF16O13ReverseParserV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "_UnicodeParser",
+                "_UTFParser"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init()",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO5UTF16OADycfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -109670,21 +116318,18 @@
                   "printedName": "Unicode.UTF16",
                   "usr": "s:s7UnicodeO5UTF16O"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO5UTF16OADycfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "decode",
               "printedName": "decode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O6decodeys0A14DecodingResultOxzStRzs6UInt16V7ElementRtzlF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<I where I : IteratorProtocol, I.Element == Unicode.UTF16.CodeUnit>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -109695,22 +116340,22 @@
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "I"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O6decodeys0A14DecodingResultOxzStRzs6UInt16V7ElementRtzlF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : IteratorProtocol, τ_0_0.Element == UInt16>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
               "kind": "Function",
               "name": "encode",
               "printedName": "encode(_:into:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O6encode_4intoyAB6ScalarV_ys6UInt16VXEtFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -109726,60 +116371,37 @@
                 {
                   "kind": "TypeFunc",
                   "name": "Function",
-                  "printedName": "(Unicode.UTF16.CodeUnit) -> Void",
-                  "typeAttributes": [
-                    "noescape"
-                  ],
+                  "printedName": "(UInt16) -> ()",
                   "children": [
                     {
-                      "kind": "TypeNameAlias",
+                      "kind": "TypeNominal",
                       "name": "Void",
-                      "printedName": "Void",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Void",
-                          "printedName": "()"
-                        }
-                      ]
+                      "printedName": "()"
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.UTF16.CodeUnit)",
-                      "usr": "s:s6UInt16V",
-                      "children": [
-                        {
-                          "kind": "TypeNameAlias",
-                          "name": "CodeUnit",
-                          "printedName": "Unicode.UTF16.CodeUnit",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt16",
-                              "printedName": "UInt16",
-                              "usr": "s:s6UInt16V"
-                            }
-                          ]
-                        }
-                      ]
+                      "name": "UInt16",
+                      "printedName": "UInt16",
+                      "usr": "s:s6UInt16V"
                     }
+                  ],
+                  "typeAttributes": [
+                    "noescape"
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O6encode_4intoyAB6ScalarV_ys6UInt16VXEtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "width",
               "printedName": "width(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O5widthySiAB6ScalarVFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -109793,33 +116415,25 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O5widthySiAB6ScalarVFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "leadSurrogate",
               "printedName": "leadSurrogate(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O13leadSurrogateys6UInt16VAB6ScalarVFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "CodeUnit",
-                  "printedName": "UTF16.CodeUnit",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt16",
-                      "printedName": "UInt16",
-                      "usr": "s:s6UInt16V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt16",
+                  "printedName": "UInt16",
+                  "usr": "s:s6UInt16V"
                 },
                 {
                   "kind": "TypeNominal",
@@ -109827,33 +116441,25 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O13leadSurrogateys6UInt16VAB6ScalarVFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "trailSurrogate",
               "printedName": "trailSurrogate(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O14trailSurrogateys6UInt16VAB6ScalarVFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "CodeUnit",
-                  "printedName": "UTF16.CodeUnit",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt16",
-                      "printedName": "UInt16",
-                      "usr": "s:s6UInt16V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt16",
+                  "printedName": "UInt16",
+                  "usr": "s:s6UInt16V"
                 },
                 {
                   "kind": "TypeNominal",
@@ -109861,20 +116467,19 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O14trailSurrogateys6UInt16VAB6ScalarVFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "isLeadSurrogate",
               "printedName": "isLeadSurrogate(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O15isLeadSurrogateySbs6UInt16VFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -109883,32 +116488,24 @@
                   "usr": "s:Sb"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "CodeUnit",
-                  "printedName": "Unicode.UTF16.CodeUnit",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt16",
-                      "printedName": "UInt16",
-                      "usr": "s:s6UInt16V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt16",
+                  "printedName": "UInt16",
+                  "usr": "s:s6UInt16V"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O15isLeadSurrogateySbs6UInt16VFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "isTrailSurrogate",
               "printedName": "isTrailSurrogate(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O16isTrailSurrogateySbs6UInt16VFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -109917,39 +116514,29 @@
                   "usr": "s:Sb"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "CodeUnit",
-                  "printedName": "Unicode.UTF16.CodeUnit",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt16",
-                      "printedName": "UInt16",
-                      "usr": "s:s6UInt16V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt16",
+                  "printedName": "UInt16",
+                  "usr": "s:s6UInt16V"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O16isTrailSurrogateySbs6UInt16VFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "transcodedLength",
               "printedName": "transcodedLength(of:decodedAs:repairingIllFormedSequences:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O16transcodedLength2of9decodedAs27repairingIllFormedSequencesSi5count_Sb7isASCIItSgx_q_mSbtStRzs01_A8EncodingR_8CodeUnitQy_7ElementRtzr0_lFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Input, Encoding where Input : IteratorProtocol, Encoding : _UnicodeEncoding, Input.Element == Encoding.CodeUnit>",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "(count: Int, isASCII: Bool)?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<(count: Int, isASCII: Bool)>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -109970,22 +116557,23 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Input"
+                  "printedName": "τ_0_0"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "Metatype",
-                  "printedName": "Encoding.Type",
+                  "printedName": "τ_0_1.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Encoding"
+                      "printedName": "τ_0_1"
                     }
                   ]
                 },
@@ -109995,57 +116583,92 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O16transcodedLength2of9decodedAs27repairingIllFormedSequencesSi5count_Sb7isASCIItSgx_q_mSbtStRzs01_A8EncodingR_8CodeUnitQy_7ElementRtzr0_lFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : IteratorProtocol, τ_0_1 : _UnicodeEncoding, τ_0_0.Element == τ_0_1.CodeUnit>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Enum",
+          "usr": "s:s7UnicodeO5UTF16O",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Frozen"
+          ],
+          "conformingProtocols": [
+            "_UnicodeEncoding",
+            "UnicodeCodec"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "UTF8",
           "printedName": "UTF8",
-          "declKind": "Enum",
-          "usr": "s:s7UnicodeO4UTF8O",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "_UnicodeEncoding",
-            "UnicodeCodec"
-          ],
-          "declAttributes": [
-            "Frozen"
-          ],
           "children": [
             {
-              "kind": "TypeAlias",
-              "name": "CodeUnit",
-              "printedName": "CodeUnit",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO4UTF8O8CodeUnita",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Var",
+              "name": "_swift3Buffer",
+              "printedName": "_swift3Buffer",
               "children": [
                 {
-                  "kind": "TypeNominal",
-                  "name": "UInt8",
-                  "printedName": "UInt8",
-                  "usr": "s:s5UInt8V"
+                  "kind": "TypeFunc",
+                  "name": "Function",
+                  "printedName": "(Unicode.UTF8.Type) -> (Unicode.UTF8.ForwardParser) -> Unicode.UTF8",
+                  "children": [
+                    {
+                      "kind": "TypeFunc",
+                      "name": "Function",
+                      "printedName": "(Unicode.UTF8.ForwardParser) -> Unicode.UTF8",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UTF8",
+                          "printedName": "Unicode.UTF8",
+                          "usr": "s:s7UnicodeO4UTF8O"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "ForwardParser",
+                          "printedName": "Unicode.UTF8.ForwardParser",
+                          "usr": "s:s7UnicodeO4UTF8O13ForwardParserV"
+                        }
+                      ]
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Metatype",
+                      "printedName": "Unicode.UTF8.Type",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UTF8",
+                          "printedName": "Unicode.UTF8",
+                          "usr": "s:s7UnicodeO4UTF8O"
+                        }
+                      ]
+                    }
+                  ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO4UTF8O13_swift3BufferyA2D13ForwardParserVcADmF",
+              "moduleName": "Swift",
+              "fixedbinaryorder": 0
             },
             {
-              "kind": "TypeAlias",
-              "name": "EncodedScalar",
-              "printedName": "EncodedScalar",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO4UTF8O13EncodedScalara",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Var",
+              "name": "encodedReplacementCharacter",
+              "printedName": "encodedReplacementCharacter",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "_ValidUTF8Buffer",
                   "printedName": "_ValidUTF8Buffer<UInt32>",
-                  "usr": "s:s16_ValidUTF8BufferV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -110053,33 +116676,18 @@
                       "printedName": "UInt32",
                       "usr": "s:s6UInt32V"
                     }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "encodedReplacementCharacter",
-              "printedName": "encodedReplacementCharacter",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO4UTF8O27encodedReplacementCharacters06_ValidB6BufferVys6UInt32VGvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
+                  ],
+                  "usr": "s:s16_ValidUTF8BufferV"
+                },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "EncodedScalar",
-                  "printedName": "Unicode.UTF8.EncodedScalar",
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "_ValidUTF8Buffer",
                       "printedName": "_ValidUTF8Buffer<UInt32>",
-                      "usr": "s:s16_ValidUTF8BufferV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -110087,58 +116695,28 @@
                           "printedName": "UInt32",
                           "usr": "s:s6UInt32V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s16_ValidUTF8BufferV"
                     }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
+                  ],
                   "declKind": "Accessor",
                   "usr": "s:s7UnicodeO4UTF8O27encodedReplacementCharacters06_ValidB6BufferVys6UInt32VGvgZ",
-                  "location": "",
                   "moduleName": "Swift",
-                  "static": true,
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "EncodedScalar",
-                      "printedName": "Unicode.UTF8.EncodedScalar",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "_ValidUTF8Buffer",
-                          "printedName": "_ValidUTF8Buffer<UInt32>",
-                          "usr": "s:s16_ValidUTF8BufferV",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt32",
-                              "printedName": "UInt32",
-                              "usr": "s:s6UInt32V"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  "static": true
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO4UTF8O27encodedReplacementCharacters06_ValidB6BufferVys6UInt32VGvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "decode",
               "printedName": "decode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO4UTF8O6decodeyAB6ScalarVs06_ValidB6BufferVys6UInt32VGFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable",
-                "Inline"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -110147,15 +116725,43 @@
                   "usr": "s:s7UnicodeO6ScalarV"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "EncodedScalar",
-                  "printedName": "Unicode.UTF8.EncodedScalar",
+                  "kind": "TypeNominal",
+                  "name": "_ValidUTF8Buffer",
+                  "printedName": "_ValidUTF8Buffer<UInt32>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt32",
+                      "printedName": "UInt32",
+                      "usr": "s:s6UInt32V"
+                    }
+                  ],
+                  "usr": "s:s16_ValidUTF8BufferV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO4UTF8O6decodeyAB6ScalarVs06_ValidB6BufferVys6UInt32VGFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable",
+                "Inline"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "encode",
+              "printedName": "encode(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<_ValidUTF8Buffer<UInt32>>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "_ValidUTF8Buffer",
                       "printedName": "_ValidUTF8Buffer<UInt32>",
-                      "usr": "s:s16_ValidUTF8BufferV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -110163,54 +116769,11 @@
                           "printedName": "UInt32",
                           "usr": "s:s6UInt32V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s16_ValidUTF8BufferV"
                     }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "encode",
-              "printedName": "encode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO4UTF8O6encodeys06_ValidB6BufferVys6UInt32VGSgAB6ScalarVFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable",
-                "Inline"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "Unicode.UTF8.EncodedScalar?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "EncodedScalar",
-                      "printedName": "Unicode.UTF8.EncodedScalar",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "_ValidUTF8Buffer",
-                          "printedName": "_ValidUTF8Buffer<UInt32>",
-                          "usr": "s:s16_ValidUTF8BufferV",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt32",
-                              "printedName": "UInt32",
-                              "usr": "s:s6UInt32V"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -110218,99 +116781,80 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO4UTF8O6encodeys06_ValidB6BufferVys6UInt32VGSgAB6ScalarVFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable",
+                "Inline"
               ]
             },
             {
               "kind": "Function",
               "name": "transcode",
               "printedName": "transcode(_:from:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO4UTF8O9transcode_4froms06_ValidB6BufferVys6UInt32VGSg13EncodedScalarQz_xmts01_A8EncodingRzlFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<FromEncoding where FromEncoding : _UnicodeEncoding>",
-              "static": true,
-              "declAttributes": [
-                "Inline",
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Unicode.UTF8.EncodedScalar?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<_ValidUTF8Buffer<UInt32>>",
                   "children": [
                     {
-                      "kind": "TypeNameAlias",
-                      "name": "EncodedScalar",
-                      "printedName": "Unicode.UTF8.EncodedScalar",
+                      "kind": "TypeNominal",
+                      "name": "_ValidUTF8Buffer",
+                      "printedName": "_ValidUTF8Buffer<UInt32>",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "_ValidUTF8Buffer",
-                          "printedName": "_ValidUTF8Buffer<UInt32>",
-                          "usr": "s:s16_ValidUTF8BufferV",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt32",
-                              "printedName": "UInt32",
-                              "usr": "s:s6UInt32V"
-                            }
-                          ]
+                          "name": "UInt32",
+                          "printedName": "UInt32",
+                          "usr": "s:s6UInt32V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s16_ValidUTF8BufferV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "FromEncoding.EncodedScalar"
+                  "printedName": "τ_0_0.EncodedScalar"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "Metatype",
-                  "printedName": "FromEncoding.Type",
+                  "printedName": "τ_0_0.Type",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "FromEncoding"
+                      "printedName": "τ_0_0"
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO4UTF8O9transcode_4froms06_ValidB6BufferVys6UInt32VGSg13EncodedScalarQz_xmts01_A8EncodingRzlFZ",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : _UnicodeEncoding>",
+              "static": true,
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "ForwardParser",
               "printedName": "ForwardParser",
-              "declKind": "Struct",
-              "usr": "s:s7UnicodeO4UTF8O13ForwardParserV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "_UnicodeParser",
-                "_UTFParser"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
               "children": [
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init()",
-                  "declKind": "Constructor",
-                  "usr": "s:s7UnicodeO4UTF8O13ForwardParserVAFycfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable",
-                    "Inline"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -110318,55 +116862,142 @@
                       "printedName": "Unicode.UTF8.ForwardParser",
                       "usr": "s:s7UnicodeO4UTF8O13ForwardParserV"
                     }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:s7UnicodeO4UTF8O13ForwardParserVAFycfc",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable",
+                    "Inline"
                   ]
                 },
                 {
-                  "kind": "TypeAlias",
-                  "name": "Encoding",
-                  "printedName": "Encoding",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO4UTF8O13ForwardParserV8Encodinga",
-                  "location": "",
-                  "moduleName": "Swift",
+                  "kind": "Var",
+                  "name": "_buffer",
+                  "printedName": "_buffer",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "UTF8",
-                      "printedName": "Unicode.UTF8",
-                      "usr": "s:s7UnicodeO4UTF8O"
+                      "name": "_UIntBuffer",
+                      "printedName": "_UIntBuffer<UInt32, UInt8>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UInt32",
+                          "printedName": "UInt32",
+                          "usr": "s:s6UInt32V"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UInt8",
+                          "printedName": "UInt8",
+                          "usr": "s:s5UInt8V"
+                        }
+                      ],
+                      "usr": "s:s11_UIntBufferV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "_UIntBuffer",
+                          "printedName": "_UIntBuffer<UInt32, UInt8>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt32",
+                              "printedName": "UInt32",
+                              "usr": "s:s6UInt32V"
+                            },
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt8",
+                              "printedName": "UInt8",
+                              "usr": "s:s5UInt8V"
+                            }
+                          ],
+                          "usr": "s:s11_UIntBufferV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO4UTF8O13ForwardParserV7_buffers11_UIntBufferVys6UInt32Vs5UInt8VGvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    },
+                    {
+                      "kind": "Setter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Void",
+                          "printedName": "()"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "_UIntBuffer",
+                          "printedName": "_UIntBuffer<UInt32, UInt8>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt32",
+                              "printedName": "UInt32",
+                              "usr": "s:s6UInt32V"
+                            },
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt8",
+                              "printedName": "UInt8",
+                              "usr": "s:s5UInt8V"
+                            }
+                          ],
+                          "usr": "s:s11_UIntBufferV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO4UTF8O13ForwardParserV7_buffers11_UIntBufferVys6UInt32Vs5UInt8VGvs",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ],
+                      "mutating": true
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO4UTF8O13ForwardParserV7_buffers11_UIntBufferVys6UInt32Vs5UInt8VGvp",
+                  "moduleName": "Swift",
+                  "fixedbinaryorder": 0,
+                  "hasStorage": true
                 }
+              ],
+              "declKind": "Struct",
+              "usr": "s:s7UnicodeO4UTF8O13ForwardParserV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "_UnicodeParser",
+                "_UTFParser"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "ReverseParser",
               "printedName": "ReverseParser",
-              "declKind": "Struct",
-              "usr": "s:s7UnicodeO4UTF8O13ReverseParserV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "_UnicodeParser",
-                "_UTFParser"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
               "children": [
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init()",
-                  "declKind": "Constructor",
-                  "usr": "s:s7UnicodeO4UTF8O13ReverseParserVAFycfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable",
-                    "Inline"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -110374,38 +117005,137 @@
                       "printedName": "Unicode.UTF8.ReverseParser",
                       "usr": "s:s7UnicodeO4UTF8O13ReverseParserV"
                     }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:s7UnicodeO4UTF8O13ReverseParserVAFycfc",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable",
+                    "Inline"
                   ]
                 },
                 {
-                  "kind": "TypeAlias",
-                  "name": "Encoding",
-                  "printedName": "Encoding",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO4UTF8O13ReverseParserV8Encodinga",
-                  "location": "",
-                  "moduleName": "Swift",
+                  "kind": "Var",
+                  "name": "_buffer",
+                  "printedName": "_buffer",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "UTF8",
-                      "printedName": "Unicode.UTF8",
-                      "usr": "s:s7UnicodeO4UTF8O"
+                      "name": "_UIntBuffer",
+                      "printedName": "_UIntBuffer<UInt32, UInt8>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UInt32",
+                          "printedName": "UInt32",
+                          "usr": "s:s6UInt32V"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UInt8",
+                          "printedName": "UInt8",
+                          "usr": "s:s5UInt8V"
+                        }
+                      ],
+                      "usr": "s:s11_UIntBufferV"
+                    },
+                    {
+                      "kind": "Getter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "_UIntBuffer",
+                          "printedName": "_UIntBuffer<UInt32, UInt8>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt32",
+                              "printedName": "UInt32",
+                              "usr": "s:s6UInt32V"
+                            },
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt8",
+                              "printedName": "UInt8",
+                              "usr": "s:s5UInt8V"
+                            }
+                          ],
+                          "usr": "s:s11_UIntBufferV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO4UTF8O13ReverseParserV7_buffers11_UIntBufferVys6UInt32Vs5UInt8VGvg",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ]
+                    },
+                    {
+                      "kind": "Setter",
+                      "name": "_",
+                      "printedName": "_()",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Void",
+                          "printedName": "()"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "_UIntBuffer",
+                          "printedName": "_UIntBuffer<UInt32, UInt8>",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt32",
+                              "printedName": "UInt32",
+                              "usr": "s:s6UInt32V"
+                            },
+                            {
+                              "kind": "TypeNominal",
+                              "name": "UInt8",
+                              "printedName": "UInt8",
+                              "usr": "s:s5UInt8V"
+                            }
+                          ],
+                          "usr": "s:s11_UIntBufferV"
+                        }
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO4UTF8O13ReverseParserV7_buffers11_UIntBufferVys6UInt32Vs5UInt8VGvs",
+                      "moduleName": "Swift",
+                      "implicit": true,
+                      "declAttributes": [
+                        "Transparent"
+                      ],
+                      "mutating": true
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO4UTF8O13ReverseParserV7_buffers11_UIntBufferVys6UInt32Vs5UInt8VGvp",
+                  "moduleName": "Swift",
+                  "fixedbinaryorder": 0,
+                  "hasStorage": true
                 }
+              ],
+              "declKind": "Struct",
+              "usr": "s:s7UnicodeO4UTF8O13ReverseParserV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "_UnicodeParser",
+                "_UTFParser"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init()",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO4UTF8OADycfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -110413,22 +117143,18 @@
                   "printedName": "Unicode.UTF8",
                   "usr": "s:s7UnicodeO4UTF8O"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO4UTF8OADycfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "decode",
               "printedName": "decode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO4UTF8O6decodeys0A14DecodingResultOxzStRzs5UInt8V7ElementRtzlF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<I where I : IteratorProtocol, I.Element == Unicode.UTF8.CodeUnit>",
-              "mutating": true,
-              "declAttributes": [
-                "Inline",
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -110439,23 +117165,23 @@
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "I"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO4UTF8O6decodeys0A14DecodingResultOxzStRzs5UInt8V7ElementRtzlF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : IteratorProtocol, τ_0_0.Element == UInt8>",
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
               "kind": "Function",
               "name": "encode",
               "printedName": "encode(_:into:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO4UTF8O6encode_4intoyAB6ScalarV_ys5UInt8VXEtFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inline",
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -110471,60 +117197,38 @@
                 {
                   "kind": "TypeFunc",
                   "name": "Function",
-                  "printedName": "(Unicode.UTF8.CodeUnit) -> Void",
-                  "typeAttributes": [
-                    "noescape"
-                  ],
+                  "printedName": "(UInt8) -> ()",
                   "children": [
                     {
-                      "kind": "TypeNameAlias",
+                      "kind": "TypeNominal",
                       "name": "Void",
-                      "printedName": "Void",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Void",
-                          "printedName": "()"
-                        }
-                      ]
+                      "printedName": "()"
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.UTF8.CodeUnit)",
-                      "usr": "s:s5UInt8V",
-                      "children": [
-                        {
-                          "kind": "TypeNameAlias",
-                          "name": "CodeUnit",
-                          "printedName": "Unicode.UTF8.CodeUnit",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt8",
-                              "printedName": "UInt8",
-                              "usr": "s:s5UInt8V"
-                            }
-                          ]
-                        }
-                      ]
+                      "name": "UInt8",
+                      "printedName": "UInt8",
+                      "usr": "s:s5UInt8V"
                     }
+                  ],
+                  "typeAttributes": [
+                    "noescape"
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO4UTF8O6encode_4intoyAB6ScalarV_ys5UInt8VXEtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "isContinuation",
               "printedName": "isContinuation(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO4UTF8O14isContinuationySbs5UInt8VFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -110533,201 +117237,178 @@
                   "usr": "s:Sb"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "CodeUnit",
-                  "printedName": "Unicode.UTF8.CodeUnit",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UInt8",
-                      "printedName": "UInt8",
-                      "usr": "s:s5UInt8V"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "UInt8",
+                  "printedName": "UInt8",
+                  "usr": "s:s5UInt8V"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO4UTF8O14isContinuationySbs5UInt8VFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Enum",
+          "usr": "s:s7UnicodeO4UTF8O",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Frozen"
+          ],
+          "conformingProtocols": [
+            "_UnicodeEncoding",
+            "UnicodeCodec"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "ParseResult",
           "printedName": "ParseResult",
-          "declKind": "Enum",
-          "usr": "s:s7UnicodeO11ParseResultO",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Frozen"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "valid",
               "printedName": "valid",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO11ParseResultO5validyADy_xGxcAFmlF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
                   "name": "GenericFunction",
-                  "printedName": "<T> (Unicode.ParseResult<T>.Type) -> (T) -> Unicode.ParseResult<T>",
+                  "printedName": "<τ_0_0> (Unicode.ParseResult<τ_0_0>.Type) -> (τ_0_0) -> Unicode.ParseResult<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeFunc",
                       "name": "Function",
-                      "printedName": "(T) -> Unicode.ParseResult<T>",
+                      "printedName": "(τ_0_0) -> Unicode.ParseResult<τ_0_0>",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "ParseResult",
-                          "printedName": "Unicode.ParseResult<T>",
-                          "usr": "s:s7UnicodeO11ParseResultO",
+                          "printedName": "Unicode.ParseResult<τ_0_0>",
                           "children": [
                             {
                               "kind": "TypeNominal",
                               "name": "GenericTypeParam",
-                              "printedName": "T"
+                              "printedName": "τ_0_0"
                             }
-                          ]
+                          ],
+                          "usr": "s:s7UnicodeO11ParseResultO"
                         },
                         {
                           "kind": "TypeNominal",
-                          "name": "Paren",
-                          "printedName": "(T)",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GenericTypeParam",
-                              "printedName": "T"
-                            }
-                          ]
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
                         }
                       ]
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.ParseResult<T>.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.ParseResult<τ_0_0>.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.ParseResult<T>.Type",
+                          "name": "ParseResult",
+                          "printedName": "Unicode.ParseResult<τ_0_0>",
                           "children": [
                             {
                               "kind": "TypeNominal",
-                              "name": "ParseResult",
-                              "printedName": "Unicode.ParseResult<T>",
-                              "usr": "s:s7UnicodeO11ParseResultO",
-                              "children": [
-                                {
-                                  "kind": "TypeNominal",
-                                  "name": "GenericTypeParam",
-                                  "printedName": "T"
-                                }
-                              ]
+                              "name": "GenericTypeParam",
+                              "printedName": "τ_0_0"
                             }
-                          ]
+                          ],
+                          "usr": "s:s7UnicodeO11ParseResultO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO11ParseResultO5validyADy_xGxcAFmlF",
+              "moduleName": "Swift",
+              "fixedbinaryorder": 0
             },
             {
               "kind": "Var",
               "name": "emptyInput",
               "printedName": "emptyInput",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO11ParseResultO10emptyInputyADy_xGAFmlF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
                   "name": "GenericFunction",
-                  "printedName": "<T> (Unicode.ParseResult<T>.Type) -> Unicode.ParseResult<T>",
+                  "printedName": "<τ_0_0> (Unicode.ParseResult<τ_0_0>.Type) -> Unicode.ParseResult<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "ParseResult",
-                      "printedName": "Unicode.ParseResult<T>",
-                      "usr": "s:s7UnicodeO11ParseResultO",
+                      "printedName": "Unicode.ParseResult<τ_0_0>",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
-                          "printedName": "T"
+                          "printedName": "τ_0_0"
                         }
-                      ]
+                      ],
+                      "usr": "s:s7UnicodeO11ParseResultO"
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.ParseResult<T>.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.ParseResult<τ_0_0>.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.ParseResult<T>.Type",
+                          "name": "ParseResult",
+                          "printedName": "Unicode.ParseResult<τ_0_0>",
                           "children": [
                             {
                               "kind": "TypeNominal",
-                              "name": "ParseResult",
-                              "printedName": "Unicode.ParseResult<T>",
-                              "usr": "s:s7UnicodeO11ParseResultO",
-                              "children": [
-                                {
-                                  "kind": "TypeNominal",
-                                  "name": "GenericTypeParam",
-                                  "printedName": "T"
-                                }
-                              ]
+                              "name": "GenericTypeParam",
+                              "printedName": "τ_0_0"
                             }
-                          ]
+                          ],
+                          "usr": "s:s7UnicodeO11ParseResultO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO11ParseResultO10emptyInputyADy_xGAFmlF",
+              "moduleName": "Swift",
+              "fixedbinaryorder": 1
             },
             {
               "kind": "Var",
               "name": "error",
               "printedName": "error",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO11ParseResultO5erroryADy_xGSi_tcAFmlF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
                   "name": "GenericFunction",
-                  "printedName": "<T> (Unicode.ParseResult<T>.Type) -> (Int) -> Unicode.ParseResult<T>",
+                  "printedName": "<τ_0_0> (Unicode.ParseResult<τ_0_0>.Type) -> (Int) -> Unicode.ParseResult<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeFunc",
                       "name": "Function",
-                      "printedName": "(Int) -> Unicode.ParseResult<T>",
+                      "printedName": "(Int) -> Unicode.ParseResult<τ_0_0>",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "ParseResult",
-                          "printedName": "Unicode.ParseResult<T>",
-                          "usr": "s:s7UnicodeO11ParseResultO",
+                          "printedName": "Unicode.ParseResult<τ_0_0>",
                           "children": [
                             {
                               "kind": "TypeNominal",
                               "name": "GenericTypeParam",
-                              "printedName": "T"
+                              "printedName": "τ_0_0"
                             }
-                          ]
+                          ],
+                          "usr": "s:s7UnicodeO11ParseResultO"
                         },
                         {
                           "kind": "TypeNominal",
@@ -110746,88 +117427,50 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.ParseResult<T>.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.ParseResult<τ_0_0>.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.ParseResult<T>.Type",
+                          "name": "ParseResult",
+                          "printedName": "Unicode.ParseResult<τ_0_0>",
                           "children": [
                             {
                               "kind": "TypeNominal",
-                              "name": "ParseResult",
-                              "printedName": "Unicode.ParseResult<T>",
-                              "usr": "s:s7UnicodeO11ParseResultO",
-                              "children": [
-                                {
-                                  "kind": "TypeNominal",
-                                  "name": "GenericTypeParam",
-                                  "printedName": "T"
-                                }
-                              ]
+                              "name": "GenericTypeParam",
+                              "printedName": "τ_0_0"
                             }
-                          ]
+                          ],
+                          "usr": "s:s7UnicodeO11ParseResultO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO11ParseResultO5erroryADy_xGSi_tcAFmlF",
+              "moduleName": "Swift",
+              "fixedbinaryorder": 2
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Version",
-          "printedName": "Version",
-          "declKind": "TypeAlias",
-          "usr": "s:s7UnicodeO7Versiona",
-          "location": "",
+          ],
+          "declKind": "Enum",
+          "usr": "s:s7UnicodeO11ParseResultO",
           "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(major: Int, minor: Int)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Frozen"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "GeneralCategory",
           "printedName": "GeneralCategory",
-          "declKind": "Enum",
-          "usr": "s:s7UnicodeO15GeneralCategoryO",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "Equatable",
-            "Hashable"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "uppercaseLetter",
               "printedName": "uppercaseLetter",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO15uppercaseLetteryA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -110842,36 +117485,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO15uppercaseLetteryA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "lowercaseLetter",
               "printedName": "lowercaseLetter",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO15lowercaseLetteryA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -110886,36 +117521,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO15lowercaseLetteryA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "titlecaseLetter",
               "printedName": "titlecaseLetter",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO15titlecaseLetteryA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -110930,36 +117557,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO15titlecaseLetteryA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "modifierLetter",
               "printedName": "modifierLetter",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO14modifierLetteryA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -110974,36 +117593,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO14modifierLetteryA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "otherLetter",
               "printedName": "otherLetter",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO11otherLetteryA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111018,36 +117629,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO11otherLetteryA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "nonspacingMark",
               "printedName": "nonspacingMark",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO14nonspacingMarkyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111062,36 +117665,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO14nonspacingMarkyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "spacingMark",
               "printedName": "spacingMark",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO11spacingMarkyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111106,36 +117701,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO11spacingMarkyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "enclosingMark",
               "printedName": "enclosingMark",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO13enclosingMarkyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111150,36 +117737,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO13enclosingMarkyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "decimalNumber",
               "printedName": "decimalNumber",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO13decimalNumberyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111194,36 +117773,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO13decimalNumberyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "letterNumber",
               "printedName": "letterNumber",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO12letterNumberyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111238,36 +117809,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO12letterNumberyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "otherNumber",
               "printedName": "otherNumber",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO11otherNumberyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111282,36 +117845,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO11otherNumberyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "connectorPunctuation",
               "printedName": "connectorPunctuation",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO20connectorPunctuationyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111326,36 +117881,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO20connectorPunctuationyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "dashPunctuation",
               "printedName": "dashPunctuation",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO15dashPunctuationyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111370,36 +117917,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO15dashPunctuationyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "openPunctuation",
               "printedName": "openPunctuation",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO15openPunctuationyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111414,36 +117953,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO15openPunctuationyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "closePunctuation",
               "printedName": "closePunctuation",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO16closePunctuationyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111458,36 +117989,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO16closePunctuationyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "initialPunctuation",
               "printedName": "initialPunctuation",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO18initialPunctuationyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111502,36 +118025,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO18initialPunctuationyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "finalPunctuation",
               "printedName": "finalPunctuation",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO16finalPunctuationyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111546,36 +118061,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO16finalPunctuationyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "otherPunctuation",
               "printedName": "otherPunctuation",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO16otherPunctuationyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111590,36 +118097,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO16otherPunctuationyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "mathSymbol",
               "printedName": "mathSymbol",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO10mathSymbolyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111634,36 +118133,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO10mathSymbolyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "currencySymbol",
               "printedName": "currencySymbol",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO14currencySymbolyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111678,36 +118169,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO14currencySymbolyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "modifierSymbol",
               "printedName": "modifierSymbol",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO14modifierSymbolyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111722,36 +118205,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO14modifierSymbolyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "otherSymbol",
               "printedName": "otherSymbol",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO11otherSymbolyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111766,36 +118241,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO11otherSymbolyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "spaceSeparator",
               "printedName": "spaceSeparator",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO14spaceSeparatoryA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111810,36 +118277,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO14spaceSeparatoryA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "lineSeparator",
               "printedName": "lineSeparator",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO13lineSeparatoryA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111854,36 +118313,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO13lineSeparatoryA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "paragraphSeparator",
               "printedName": "paragraphSeparator",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO18paragraphSeparatoryA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111898,36 +118349,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO18paragraphSeparatoryA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "control",
               "printedName": "control",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO7controlyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111942,36 +118385,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO7controlyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "format",
               "printedName": "format",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO6formatyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111986,36 +118421,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO6formatyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "surrogate",
               "printedName": "surrogate",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO9surrogateyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -112030,36 +118457,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO9surrogateyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "privateUse",
               "printedName": "privateUse",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO10privateUseyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -112074,36 +118493,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO10privateUseyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "unassigned",
               "printedName": "unassigned",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO10unassignedyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -112118,36 +118529,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.GeneralCategory.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.GeneralCategory.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.GeneralCategory.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GeneralCategory",
-                              "printedName": "Unicode.GeneralCategory",
-                              "usr": "s:s7UnicodeO15GeneralCategoryO"
-                            }
-                          ]
+                          "name": "GeneralCategory",
+                          "printedName": "Unicode.GeneralCategory",
+                          "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO10unassignedyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(rawValue:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO15GeneralCategoryO8rawValueADSo020__swift_stdlib_UCharC0V_tcfc",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112161,16 +118564,49 @@
                   "printedName": "__swift_stdlib_UCharCategory",
                   "usr": "c:@E@__swift_stdlib_UCharCategory"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO15GeneralCategoryO8rawValueADSo020__swift_stdlib_UCharC0V_tcfc",
+              "moduleName": "Swift",
+              "isInternal": true
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GeneralCategory",
+                  "printedName": "Unicode.GeneralCategory",
+                  "usr": "s:s7UnicodeO15GeneralCategoryO"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GeneralCategory",
+                  "printedName": "Unicode.GeneralCategory",
+                  "usr": "s:s7UnicodeO15GeneralCategoryO"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO15GeneralCategoryO2eeoiySbAD_ADtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "implicit": true,
+              "declAttributes": [
+                "Infix"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO15GeneralCategoryO9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112182,10 +118618,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO15GeneralCategoryO9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112193,18 +118625,22 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO15GeneralCategoryO9hashValueSivg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO15GeneralCategoryO9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO15GeneralCategoryO4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112217,37 +118653,30 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO15GeneralCategoryO4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Enum",
+          "usr": "s:s7UnicodeO15GeneralCategoryO",
+          "moduleName": "Swift",
+          "conformingProtocols": [
+            "Equatable",
+            "Hashable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "CanonicalCombiningClass",
           "printedName": "CanonicalCombiningClass",
-          "declKind": "Struct",
-          "usr": "s:s7UnicodeO23CanonicalCombiningClassV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "Comparable",
-            "Hashable",
-            "RawRepresentable",
-            "Equatable"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "notReordered",
               "printedName": "notReordered",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV12notReorderedADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112259,11 +118688,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV12notReorderedADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112271,22 +118695,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV12notReorderedADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV12notReorderedADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "overlay",
               "printedName": "overlay",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV7overlayADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112298,11 +118728,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV7overlayADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112310,22 +118735,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV7overlayADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV7overlayADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "nukta",
               "printedName": "nukta",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV5nuktaADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112337,11 +118768,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV5nuktaADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112349,22 +118775,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV5nuktaADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV5nuktaADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "kanaVoicing",
               "printedName": "kanaVoicing",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV11kanaVoicingADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112376,11 +118808,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV11kanaVoicingADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112388,22 +118815,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV11kanaVoicingADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV11kanaVoicingADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "virama",
               "printedName": "virama",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV6viramaADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112415,11 +118848,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV6viramaADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112427,22 +118855,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV6viramaADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV6viramaADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "attachedBelowLeft",
               "printedName": "attachedBelowLeft",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV17attachedBelowLeftADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112454,11 +118888,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV17attachedBelowLeftADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112466,22 +118895,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV17attachedBelowLeftADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV17attachedBelowLeftADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "attachedBelow",
               "printedName": "attachedBelow",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV13attachedBelowADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112493,11 +118928,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV13attachedBelowADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112505,22 +118935,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV13attachedBelowADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV13attachedBelowADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "attachedAbove",
               "printedName": "attachedAbove",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV13attachedAboveADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112532,11 +118968,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV13attachedAboveADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112544,22 +118975,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV13attachedAboveADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV13attachedAboveADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "attachedAboveRight",
               "printedName": "attachedAboveRight",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV18attachedAboveRightADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112571,11 +119008,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV18attachedAboveRightADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112583,22 +119015,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV18attachedAboveRightADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV18attachedAboveRightADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "belowLeft",
               "printedName": "belowLeft",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV9belowLeftADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112610,11 +119048,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV9belowLeftADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112622,22 +119055,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV9belowLeftADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV9belowLeftADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "below",
               "printedName": "below",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV5belowADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112649,11 +119088,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV5belowADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112661,22 +119095,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV5belowADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV5belowADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "belowRight",
               "printedName": "belowRight",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV10belowRightADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112688,11 +119128,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV10belowRightADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112700,22 +119135,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV10belowRightADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV10belowRightADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "left",
               "printedName": "left",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV4leftADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112727,11 +119168,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV4leftADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112739,22 +119175,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV4leftADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV4leftADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "right",
               "printedName": "right",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV5rightADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112766,11 +119208,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV5rightADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112778,22 +119215,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV5rightADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV5rightADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "aboveLeft",
               "printedName": "aboveLeft",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV9aboveLeftADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112805,11 +119248,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV9aboveLeftADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112817,22 +119255,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV9aboveLeftADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV9aboveLeftADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "above",
               "printedName": "above",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV5aboveADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112844,11 +119288,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV5aboveADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112856,22 +119295,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV5aboveADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV5aboveADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "aboveRight",
               "printedName": "aboveRight",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV10aboveRightADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112883,11 +119328,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV10aboveRightADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112895,22 +119335,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV10aboveRightADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV10aboveRightADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "doubleBelow",
               "printedName": "doubleBelow",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV11doubleBelowADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112922,11 +119368,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV11doubleBelowADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112934,22 +119375,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV11doubleBelowADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV11doubleBelowADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "doubleAbove",
               "printedName": "doubleAbove",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV11doubleAboveADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112961,11 +119408,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV11doubleAboveADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112973,22 +119415,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV11doubleAboveADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV11doubleAboveADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "iotaSubscript",
               "printedName": "iotaSubscript",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV13iotaSubscriptADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113000,11 +119448,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV13iotaSubscriptADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -113012,18 +119455,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV13iotaSubscriptADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV13iotaSubscriptADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "rawValue",
               "printedName": "rawValue",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV8rawValues5UInt8Vvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113035,10 +119488,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV8rawValues5UInt8Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -113046,18 +119495,23 @@
                       "printedName": "UInt8",
                       "usr": "s:s5UInt8V"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV8rawValues5UInt8Vvg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV8rawValues5UInt8Vvp",
+              "moduleName": "Swift",
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(rawValue:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV8rawValueADs5UInt8V_tcfc",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113071,33 +119525,44 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV8rawValueADs5UInt8V_tcfc",
+              "moduleName": "Swift"
             },
             {
-              "kind": "TypeAlias",
-              "name": "RawValue",
-              "printedName": "RawValue",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV8RawValuea",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "UInt8",
-                  "printedName": "UInt8",
-                  "usr": "s:s5UInt8V"
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "CanonicalCombiningClass",
+                  "printedName": "Unicode.CanonicalCombiningClass",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "CanonicalCombiningClass",
+                  "printedName": "Unicode.CanonicalCombiningClass",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV1loiySbAD_ADtFZ",
+              "moduleName": "Swift",
+              "static": true
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113109,10 +119574,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -113120,18 +119581,22 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV9hashValueSivg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113144,31 +119609,32 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s7UnicodeO23CanonicalCombiningClassV",
+          "moduleName": "Swift",
+          "conformingProtocols": [
+            "Comparable",
+            "Hashable",
+            "RawRepresentable",
+            "Equatable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "NumericType",
           "printedName": "NumericType",
-          "declKind": "Enum",
-          "usr": "s:s7UnicodeO11NumericTypeO",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "Equatable",
-            "Hashable"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "decimal",
               "printedName": "decimal",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO11NumericTypeO7decimalyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -113183,36 +119649,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.NumericType.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.NumericType.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.NumericType.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "NumericType",
-                              "printedName": "Unicode.NumericType",
-                              "usr": "s:s7UnicodeO11NumericTypeO"
-                            }
-                          ]
+                          "name": "NumericType",
+                          "printedName": "Unicode.NumericType",
+                          "usr": "s:s7UnicodeO11NumericTypeO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO11NumericTypeO7decimalyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "digit",
               "printedName": "digit",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO11NumericTypeO5digityA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -113227,36 +119685,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.NumericType.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.NumericType.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.NumericType.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "NumericType",
-                              "printedName": "Unicode.NumericType",
-                              "usr": "s:s7UnicodeO11NumericTypeO"
-                            }
-                          ]
+                          "name": "NumericType",
+                          "printedName": "Unicode.NumericType",
+                          "usr": "s:s7UnicodeO11NumericTypeO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO11NumericTypeO5digityA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "numeric",
               "printedName": "numeric",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO11NumericTypeO7numericyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -113271,42 +119721,33 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.NumericType.Type)",
+                      "name": "Metatype",
+                      "printedName": "Unicode.NumericType.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Unicode.NumericType.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "NumericType",
-                              "printedName": "Unicode.NumericType",
-                              "usr": "s:s7UnicodeO11NumericTypeO"
-                            }
-                          ]
+                          "name": "NumericType",
+                          "printedName": "Unicode.NumericType",
+                          "usr": "s:s7UnicodeO11NumericTypeO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO11NumericTypeO7numericyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(rawValue:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO11NumericTypeO8rawValueADSgSo023__swift_stdlib_UNumericC0V_tcfc",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Unicode.NumericType?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<Unicode.NumericType>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -113314,7 +119755,8 @@
                       "printedName": "Unicode.NumericType",
                       "usr": "s:s7UnicodeO11NumericTypeO"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -113322,16 +119764,49 @@
                   "printedName": "__swift_stdlib_UNumericType",
                   "usr": "c:@E@__swift_stdlib_UNumericType"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO11NumericTypeO8rawValueADSgSo023__swift_stdlib_UNumericC0V_tcfc",
+              "moduleName": "Swift",
+              "isInternal": true
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "NumericType",
+                  "printedName": "Unicode.NumericType",
+                  "usr": "s:s7UnicodeO11NumericTypeO"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "NumericType",
+                  "printedName": "Unicode.NumericType",
+                  "usr": "s:s7UnicodeO11NumericTypeO"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO11NumericTypeO2eeoiySbAD_ADtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "implicit": true,
+              "declAttributes": [
+                "Infix"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO11NumericTypeO9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113343,10 +119818,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO11NumericTypeO9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -113354,18 +119825,22 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO11NumericTypeO9hashValueSivg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO11NumericTypeO9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO11NumericTypeO4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113378,36 +119853,100 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO11NumericTypeO4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Enum",
+          "usr": "s:s7UnicodeO11NumericTypeO",
+          "moduleName": "Swift",
+          "conformingProtocols": [
+            "Equatable",
+            "Hashable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "UTF32",
           "printedName": "UTF32",
-          "declKind": "Enum",
-          "usr": "s:s7UnicodeO5UTF32O",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "Equatable",
-            "Hashable",
-            "_UnicodeEncoding",
-            "UnicodeCodec"
-          ],
-          "declAttributes": [
-            "Frozen"
-          ],
           "children": [
             {
               "kind": "Var",
+              "name": "_swift3Codec",
+              "printedName": "_swift3Codec",
+              "children": [
+                {
+                  "kind": "TypeFunc",
+                  "name": "Function",
+                  "printedName": "(Unicode.UTF32.Type) -> Unicode.UTF32",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UTF32",
+                      "printedName": "Unicode.UTF32",
+                      "usr": "s:s7UnicodeO5UTF32O"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Metatype",
+                      "printedName": "Unicode.UTF32.Type",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UTF32",
+                          "printedName": "Unicode.UTF32",
+                          "usr": "s:s7UnicodeO5UTF32O"
+                        }
+                      ]
+                    }
+                  ]
+                }
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO5UTF32O12_swift3CodecyA2DmF",
+              "moduleName": "Swift",
+              "fixedbinaryorder": 0
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF32",
+                  "printedName": "Unicode.UTF32",
+                  "usr": "s:s7UnicodeO5UTF32O"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF32",
+                  "printedName": "Unicode.UTF32",
+                  "usr": "s:s7UnicodeO5UTF32O"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF32O2eeoiySbAD_ADtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "implicit": true,
+              "declAttributes": [
+                "Infix"
+              ]
+            },
+            {
+              "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO5UTF32O9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113419,10 +119958,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO5UTF32O9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -113430,18 +119965,22 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO5UTF32O9hashValueSivg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO5UTF32O9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF32O4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113454,39 +119993,21 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF32O4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
-              "kind": "TypeAlias",
-              "name": "CodeUnit",
-              "printedName": "CodeUnit",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5UTF32O8CodeUnita",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt32",
-                  "printedName": "UInt32",
-                  "usr": "s:s6UInt32V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "EncodedScalar",
-              "printedName": "EncodedScalar",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5UTF32O13EncodedScalara",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Var",
+              "name": "encodedReplacementCharacter",
+              "printedName": "encodedReplacementCharacter",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "CollectionOfOne",
                   "printedName": "CollectionOfOne<UInt32>",
-                  "usr": "s:s15CollectionOfOneV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -113494,33 +120015,18 @@
                       "printedName": "UInt32",
                       "usr": "s:s6UInt32V"
                     }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "encodedReplacementCharacter",
-              "printedName": "encodedReplacementCharacter",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO5UTF32O27encodedReplacementCharacters15CollectionOfOneVys6UInt32VGvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
+                  ],
+                  "usr": "s:s15CollectionOfOneV"
+                },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "EncodedScalar",
-                  "printedName": "Unicode.UTF32.EncodedScalar",
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "CollectionOfOne",
                       "printedName": "CollectionOfOne<UInt32>",
-                      "usr": "s:s15CollectionOfOneV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -113528,58 +120034,28 @@
                           "printedName": "UInt32",
                           "usr": "s:s6UInt32V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s15CollectionOfOneV"
                     }
-                  ]
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
+                  ],
                   "declKind": "Accessor",
                   "usr": "s:s7UnicodeO5UTF32O27encodedReplacementCharacters15CollectionOfOneVys6UInt32VGvgZ",
-                  "location": "",
                   "moduleName": "Swift",
-                  "static": true,
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "EncodedScalar",
-                      "printedName": "Unicode.UTF32.EncodedScalar",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "CollectionOfOne",
-                          "printedName": "CollectionOfOne<UInt32>",
-                          "usr": "s:s15CollectionOfOneV",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt32",
-                              "printedName": "UInt32",
-                              "usr": "s:s6UInt32V"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  "static": true
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO5UTF32O27encodedReplacementCharacters15CollectionOfOneVys6UInt32VGvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "decode",
               "printedName": "decode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF32O6decodeyAB6ScalarVs15CollectionOfOneVys6UInt32VGFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inline",
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113588,15 +120064,43 @@
                   "usr": "s:s7UnicodeO6ScalarV"
                 },
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "EncodedScalar",
-                  "printedName": "Unicode.UTF32.EncodedScalar",
+                  "kind": "TypeNominal",
+                  "name": "CollectionOfOne",
+                  "printedName": "CollectionOfOne<UInt32>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt32",
+                      "printedName": "UInt32",
+                      "usr": "s:s6UInt32V"
+                    }
+                  ],
+                  "usr": "s:s15CollectionOfOneV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF32O6decodeyAB6ScalarVs15CollectionOfOneVys6UInt32VGFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "encode",
+              "printedName": "encode(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<CollectionOfOne<UInt32>>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "CollectionOfOne",
                       "printedName": "CollectionOfOne<UInt32>",
-                      "usr": "s:s15CollectionOfOneV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -113604,54 +120108,11 @@
                           "printedName": "UInt32",
                           "usr": "s:s6UInt32V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s15CollectionOfOneV"
                     }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "encode",
-              "printedName": "encode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF32O6encodeys15CollectionOfOneVys6UInt32VGSgAB6ScalarVFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inline",
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "Unicode.UTF32.EncodedScalar?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "EncodedScalar",
-                      "printedName": "Unicode.UTF32.EncodedScalar",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "CollectionOfOne",
-                          "printedName": "CollectionOfOne<UInt32>",
-                          "usr": "s:s15CollectionOfOneV",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt32",
-                              "printedName": "UInt32",
-                              "usr": "s:s6UInt32V"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -113659,34 +120120,25 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF32O6encodeys15CollectionOfOneVys6UInt32VGSgAB6ScalarVFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "Parser",
               "printedName": "Parser",
-              "declKind": "Struct",
-              "usr": "s:s7UnicodeO5UTF32O6ParserV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "_UnicodeParser"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
               "children": [
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init()",
-                  "declKind": "Constructor",
-                  "usr": "s:s7UnicodeO5UTF32O6ParserVAFycfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -113694,122 +120146,71 @@
                       "printedName": "Unicode.UTF32.Parser",
                       "usr": "s:s7UnicodeO5UTF32O6ParserV"
                     }
-                  ]
-                },
-                {
-                  "kind": "TypeAlias",
-                  "name": "Encoding",
-                  "printedName": "Encoding",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO5UTF32O6ParserV8Encodinga",
-                  "location": "",
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:s7UnicodeO5UTF32O6ParserVAFycfc",
                   "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UTF32",
-                      "printedName": "Unicode.UTF32",
-                      "usr": "s:s7UnicodeO5UTF32O"
-                    }
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
                   "kind": "Function",
                   "name": "parseScalar",
                   "printedName": "parseScalar(from:)",
-                  "declKind": "Func",
-                  "usr": "s:s7UnicodeO5UTF32O6ParserV11parseScalar4fromAB11ParseResultOy_s15CollectionOfOneVys6UInt32VGGxz_tStRzAN7ElementRtzlF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<I where I : IteratorProtocol, I.Element == Unicode.UTF32.Parser.Encoding.CodeUnit>",
-                  "mutating": true,
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "ParseResult",
-                      "printedName": "Unicode.ParseResult<Unicode.UTF32.Parser.Encoding.EncodedScalar>",
-                      "usr": "s:s7UnicodeO11ParseResultO",
+                      "printedName": "Unicode.ParseResult<CollectionOfOne<UInt32>>",
                       "children": [
                         {
-                          "kind": "TypeNameAlias",
-                          "name": "EncodedScalar",
-                          "printedName": "Unicode.UTF32.Parser.Encoding.EncodedScalar",
+                          "kind": "TypeNominal",
+                          "name": "CollectionOfOne",
+                          "printedName": "CollectionOfOne<UInt32>",
                           "children": [
                             {
                               "kind": "TypeNominal",
-                              "name": "CollectionOfOne",
-                              "printedName": "CollectionOfOne<UInt32>",
-                              "usr": "s:s15CollectionOfOneV",
-                              "children": [
-                                {
-                                  "kind": "TypeNominal",
-                                  "name": "UInt32",
-                                  "printedName": "UInt32",
-                                  "usr": "s:s6UInt32V"
-                                }
-                              ]
+                              "name": "UInt32",
+                              "printedName": "UInt32",
+                              "usr": "s:s6UInt32V"
                             }
-                          ]
+                          ],
+                          "usr": "s:s15CollectionOfOneV"
                         }
-                      ]
+                      ],
+                      "usr": "s:s7UnicodeO11ParseResultO"
                     },
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "I"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:s7UnicodeO5UTF32O6ParserV11parseScalar4fromAB11ParseResultOy_s15CollectionOfOneVys6UInt32VGGxz_tStRzAN7ElementRtzlF",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0 where τ_0_0 : IteratorProtocol, τ_0_0.Element == UInt32>",
+                  "declAttributes": [
+                    "Inlinable"
+                  ],
+                  "mutating": true
                 }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "ForwardParser",
-              "printedName": "ForwardParser",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5UTF32O13ForwardParsera",
-              "location": "",
+              ],
+              "declKind": "Struct",
+              "usr": "s:s7UnicodeO5UTF32O6ParserV",
               "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Parser",
-                  "printedName": "Unicode.UTF32.Parser",
-                  "usr": "s:s7UnicodeO5UTF32O6ParserV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "ReverseParser",
-              "printedName": "ReverseParser",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5UTF32O13ReverseParsera",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Parser",
-                  "printedName": "Unicode.UTF32.Parser",
-                  "usr": "s:s7UnicodeO5UTF32O6ParserV"
-                }
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "_UnicodeParser"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init()",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO5UTF32OADycfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113817,21 +120218,18 @@
                   "printedName": "Unicode.UTF32",
                   "usr": "s:s7UnicodeO5UTF32O"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO5UTF32OADycfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "decode",
               "printedName": "decode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF32O6decodeys0A14DecodingResultOxzStRzs6UInt32V7ElementRtzlF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<I where I : IteratorProtocol, I.Element == Unicode.UTF32.CodeUnit>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113842,22 +120240,22 @@
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "I"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF32O6decodeys0A14DecodingResultOxzStRzs6UInt32V7ElementRtzlF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : IteratorProtocol, τ_0_0.Element == UInt32>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
               "kind": "Function",
               "name": "encode",
               "printedName": "encode(_:into:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF32O6encode_4intoyAB6ScalarV_ys6UInt32VXEtFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113873,2064 +120271,242 @@
                 {
                   "kind": "TypeFunc",
                   "name": "Function",
-                  "printedName": "(Unicode.UTF32.CodeUnit) -> Void",
-                  "typeAttributes": [
-                    "noescape"
-                  ],
+                  "printedName": "(UInt32) -> ()",
                   "children": [
                     {
-                      "kind": "TypeNameAlias",
+                      "kind": "TypeNominal",
                       "name": "Void",
-                      "printedName": "Void",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Void",
-                          "printedName": "()"
-                        }
-                      ]
+                      "printedName": "()"
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Unicode.UTF32.CodeUnit)",
-                      "usr": "s:s6UInt32V",
-                      "children": [
-                        {
-                          "kind": "TypeNameAlias",
-                          "name": "CodeUnit",
-                          "printedName": "Unicode.UTF32.CodeUnit",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "UInt32",
-                              "printedName": "UInt32",
-                              "usr": "s:s6UInt32V"
-                            }
-                          ]
-                        }
-                      ]
+                      "name": "UInt32",
+                      "printedName": "UInt32",
+                      "usr": "s:s6UInt32V"
                     }
+                  ],
+                  "typeAttributes": [
+                    "noescape"
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF32O6encode_4intoyAB6ScalarV_ys6UInt32VXEtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Enum",
+          "usr": "s:s7UnicodeO5UTF32O",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Frozen"
+          ],
+          "conformingProtocols": [
+            "Equatable",
+            "Hashable",
+            "_UnicodeEncoding",
+            "UnicodeCodec"
           ]
         }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "BidirectionalIndexable",
-      "printedName": "BidirectionalIndexable",
-      "declKind": "TypeAlias",
-      "usr": "s:s22BidirectionalIndexablea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
       ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "BidirectionalCollection",
-          "printedName": "BidirectionalCollection",
-          "usr": "s:SK"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "IndexableBase",
-      "printedName": "IndexableBase",
-      "declKind": "TypeAlias",
-      "usr": "s:s13IndexableBasea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Collection",
-          "printedName": "Collection",
-          "usr": "s:Sl"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "Indexable",
-      "printedName": "Indexable",
-      "declKind": "TypeAlias",
-      "usr": "s:s9Indexablea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Collection",
-          "printedName": "Collection",
-          "usr": "s:Sl"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "MutableIndexable",
-      "printedName": "MutableIndexable",
-      "declKind": "TypeAlias",
-      "usr": "s:s16MutableIndexablea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "MutableCollection",
-          "printedName": "MutableCollection",
-          "usr": "s:SM"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "RandomAccessIndexable",
-      "printedName": "RandomAccessIndexable",
-      "declKind": "TypeAlias",
-      "usr": "s:s21RandomAccessIndexablea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "RandomAccessCollection",
-          "printedName": "RandomAccessCollection",
-          "usr": "s:Sk"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "RangeReplaceableIndexable",
-      "printedName": "RangeReplaceableIndexable",
-      "declKind": "TypeAlias",
-      "usr": "s:s25RangeReplaceableIndexablea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "RangeReplaceableCollection",
-          "printedName": "RangeReplaceableCollection",
-          "usr": "s:Sm"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "EnumeratedIterator",
-      "printedName": "EnumeratedIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s18EnumeratedIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Sequence>",
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Iterator",
-          "printedName": "EnumeratedSequence<T>.Iterator",
-          "usr": "s:s18EnumeratedSequenceV8IteratorV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "IteratorOverOne",
-      "printedName": "IteratorOverOne",
-      "declKind": "TypeAlias",
-      "usr": "s:s15IteratorOverOnea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Iterator",
-          "printedName": "CollectionOfOne<T>.Iterator",
-          "usr": "s:s15CollectionOfOneV8IteratorV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "EmptyIterator",
-      "printedName": "EmptyIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s13EmptyIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Iterator",
-          "printedName": "EmptyCollection<T>.Iterator",
-          "usr": "s:s15EmptyCollectionV8IteratorV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "LazyFilterIterator",
-      "printedName": "LazyFilterIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s18LazyFilterIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Sequence>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Iterator",
-          "printedName": "LazyFilterSequence<T>.Iterator",
-          "usr": "s:s18LazyFilterSequenceV8IteratorV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "LazyFilterIndex",
-      "printedName": "LazyFilterIndex",
-      "declKind": "TypeAlias",
-      "usr": "s:s15LazyFilterIndexa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Collection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "DependentMember",
-          "printedName": "Base.Index"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "LazyDropWhileIterator",
-      "printedName": "LazyDropWhileIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s21LazyDropWhileIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Sequence>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Iterator",
-          "printedName": "LazyDropWhileSequence<T>.Iterator",
-          "usr": "s:s21LazyDropWhileSequenceV8IteratorV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "LazyDropWhileIndex",
-      "printedName": "LazyDropWhileIndex",
-      "declKind": "TypeAlias",
-      "usr": "s:s18LazyDropWhileIndexa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Collection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Index",
-          "printedName": "LazyDropWhileCollection<T>.Index",
-          "usr": "s:s23LazyDropWhileCollectionV5IndexV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "LazyDropWhileBidirectionalCollection",
-      "printedName": "LazyDropWhileBidirectionalCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s36LazyDropWhileBidirectionalCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "LazyDropWhileCollection",
-          "printedName": "LazyDropWhileCollection<T>",
-          "usr": "s:s23LazyDropWhileCollectionV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "LazyFilterBidirectionalCollection",
-      "printedName": "LazyFilterBidirectionalCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s33LazyFilterBidirectionalCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "LazyFilterCollection",
-          "printedName": "LazyFilterCollection<T>",
-          "usr": "s:s20LazyFilterCollectionV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "LazyMapIterator",
-      "printedName": "LazyMapIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s15LazyMapIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, E where T : Sequence>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Iterator",
-          "printedName": "LazyMapSequence<T, E>.Iterator",
-          "usr": "s:s15LazyMapSequenceV8IteratorV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "LazyMapBidirectionalCollection",
-      "printedName": "LazyMapBidirectionalCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s30LazyMapBidirectionalCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, E where T : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "LazyMapCollection",
-          "printedName": "LazyMapCollection<T, E>",
-          "usr": "s:s17LazyMapCollectionV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "E"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "LazyMapRandomAccessCollection",
-      "printedName": "LazyMapRandomAccessCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s29LazyMapRandomAccessCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, E where T : RandomAccessCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "LazyMapCollection",
-          "printedName": "LazyMapCollection<T, E>",
-          "usr": "s:s17LazyMapCollectionV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "E"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "LazyBidirectionalCollection",
-      "printedName": "LazyBidirectionalCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s27LazyBidirectionalCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "LazyCollection",
-          "printedName": "LazyCollection<T>",
-          "usr": "s:s14LazyCollectionV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "LazyRandomAccessCollection",
-      "printedName": "LazyRandomAccessCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s26LazyRandomAccessCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : RandomAccessCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "LazyCollection",
-          "printedName": "LazyCollection<T>",
-          "usr": "s:s14LazyCollectionV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "FlattenCollectionIndex",
-      "printedName": "FlattenCollectionIndex",
-      "declKind": "TypeAlias",
-      "usr": "s:s22FlattenCollectionIndexa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Collection, T.Element : Collection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Index",
-          "printedName": "FlattenCollection<T>.Index",
-          "usr": "s:s17FlattenCollectionV5IndexV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "FlattenBidirectionalCollectionIndex",
-      "printedName": "FlattenBidirectionalCollectionIndex",
-      "declKind": "TypeAlias",
-      "usr": "s:s35FlattenBidirectionalCollectionIndexa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection, T.Element : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Index",
-          "printedName": "FlattenCollection<T>.Index",
-          "usr": "s:s17FlattenCollectionV5IndexV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "FlattenBidirectionalCollection",
-      "printedName": "FlattenBidirectionalCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s30FlattenBidirectionalCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection, T.Element : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "FlattenCollection",
-          "printedName": "FlattenCollection<T>",
-          "usr": "s:s17FlattenCollectionV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "JoinedIterator",
-      "printedName": "JoinedIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s14JoinedIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Sequence, T.Element : Sequence>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Iterator",
-          "printedName": "JoinedSequence<T>.Iterator",
-          "usr": "s:s14JoinedSequenceV8IteratorV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "Zip2Iterator",
-      "printedName": "Zip2Iterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s12Zip2Iteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, U where T : Sequence, U : Sequence>",
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Iterator",
-          "printedName": "Zip2Sequence<T, U>.Iterator",
-          "usr": "s:s12Zip2SequenceV8IteratorV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "LazyPrefixWhileIterator",
-      "printedName": "LazyPrefixWhileIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s23LazyPrefixWhileIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Sequence>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Iterator",
-          "printedName": "LazyPrefixWhileSequence<T>.Iterator",
-          "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "LazyPrefixWhileIndex",
-      "printedName": "LazyPrefixWhileIndex",
-      "declKind": "TypeAlias",
-      "usr": "s:s20LazyPrefixWhileIndexa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Collection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Index",
-          "printedName": "LazyPrefixWhileCollection<T>.Index",
-          "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "LazyPrefixWhileBidirectionalCollection",
-      "printedName": "LazyPrefixWhileBidirectionalCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s38LazyPrefixWhileBidirectionalCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "LazyPrefixWhileCollection",
-          "printedName": "LazyPrefixWhileCollection<T>",
-          "usr": "s:s25LazyPrefixWhileCollectionV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "ReversedRandomAccessCollection",
-      "printedName": "ReversedRandomAccessCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s30ReversedRandomAccessCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : RandomAccessCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ReversedCollection",
-          "printedName": "ReversedCollection<T>",
-          "usr": "s:s18ReversedCollectionV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "ReversedIndex",
-      "printedName": "ReversedIndex",
-      "declKind": "TypeAlias",
-      "usr": "s:s13ReversedIndexa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ReversedCollection",
-          "printedName": "ReversedCollection<T>",
-          "usr": "s:s18ReversedCollectionV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "BidirectionalSlice",
-      "printedName": "BidirectionalSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s18BidirectionalSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Slice",
-          "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "RandomAccessSlice",
-      "printedName": "RandomAccessSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s17RandomAccessSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : RandomAccessCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Slice",
-          "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "RangeReplaceableSlice",
-      "printedName": "RangeReplaceableSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s21RangeReplaceableSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : RangeReplaceableCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Slice",
-          "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "RangeReplaceableBidirectionalSlice",
-      "printedName": "RangeReplaceableBidirectionalSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s34RangeReplaceableBidirectionalSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection, T : RangeReplaceableCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Slice",
-          "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "RangeReplaceableRandomAccessSlice",
-      "printedName": "RangeReplaceableRandomAccessSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s33RangeReplaceableRandomAccessSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : RandomAccessCollection, T : RangeReplaceableCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Slice",
-          "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "MutableSlice",
-      "printedName": "MutableSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s12MutableSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : MutableCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Slice",
-          "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "MutableBidirectionalSlice",
-      "printedName": "MutableBidirectionalSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s25MutableBidirectionalSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection, T : MutableCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Slice",
-          "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "MutableRandomAccessSlice",
-      "printedName": "MutableRandomAccessSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s24MutableRandomAccessSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : MutableCollection, T : RandomAccessCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Slice",
-          "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "MutableRangeReplaceableSlice",
-      "printedName": "MutableRangeReplaceableSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s28MutableRangeReplaceableSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : MutableCollection, T : RangeReplaceableCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Slice",
-          "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "MutableRangeReplaceableBidirectionalSlice",
-      "printedName": "MutableRangeReplaceableBidirectionalSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s41MutableRangeReplaceableBidirectionalSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection, T : MutableCollection, T : RangeReplaceableCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Slice",
-          "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "MutableRangeReplaceableRandomAccessSlice",
-      "printedName": "MutableRangeReplaceableRandomAccessSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s40MutableRangeReplaceableRandomAccessSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : MutableCollection, T : RandomAccessCollection, T : RangeReplaceableCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Slice",
-          "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "DefaultBidirectionalIndices",
-      "printedName": "DefaultBidirectionalIndices",
-      "declKind": "TypeAlias",
-      "usr": "s:s27DefaultBidirectionalIndicesa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "DefaultIndices",
-          "printedName": "DefaultIndices<T>",
-          "usr": "s:SI",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "DefaultRandomAccessIndices",
-      "printedName": "DefaultRandomAccessIndices",
-      "declKind": "TypeAlias",
-      "usr": "s:s26DefaultRandomAccessIndicesa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : RandomAccessCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "DefaultIndices",
-          "printedName": "DefaultIndices<T>",
-          "usr": "s:SI",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "NilLiteralConvertible",
-      "printedName": "NilLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s21NilLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ExpressibleByNilLiteral",
-          "printedName": "ExpressibleByNilLiteral",
-          "usr": "s:s23ExpressibleByNilLiteralP"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "IntegerLiteralConvertible",
-      "printedName": "IntegerLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s25IntegerLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ExpressibleByIntegerLiteral",
-          "printedName": "ExpressibleByIntegerLiteral",
-          "usr": "s:s27ExpressibleByIntegerLiteralP"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "FloatLiteralConvertible",
-      "printedName": "FloatLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s23FloatLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ExpressibleByFloatLiteral",
-          "printedName": "ExpressibleByFloatLiteral",
-          "usr": "s:s25ExpressibleByFloatLiteralP"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "BooleanLiteralConvertible",
-      "printedName": "BooleanLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s25BooleanLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ExpressibleByBooleanLiteral",
-          "printedName": "ExpressibleByBooleanLiteral",
-          "usr": "s:s27ExpressibleByBooleanLiteralP"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "UnicodeScalarLiteralConvertible",
-      "printedName": "UnicodeScalarLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s31UnicodeScalarLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ExpressibleByUnicodeScalarLiteral",
-          "printedName": "ExpressibleByUnicodeScalarLiteral",
-          "usr": "s:s33ExpressibleByUnicodeScalarLiteralP"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "ExtendedGraphemeClusterLiteralConvertible",
-      "printedName": "ExtendedGraphemeClusterLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s41ExtendedGraphemeClusterLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ExpressibleByExtendedGraphemeClusterLiteral",
-          "printedName": "ExpressibleByExtendedGraphemeClusterLiteral",
-          "usr": "s:s43ExpressibleByExtendedGraphemeClusterLiteralP"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "StringLiteralConvertible",
-      "printedName": "StringLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s24StringLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ExpressibleByStringLiteral",
-          "printedName": "ExpressibleByStringLiteral",
-          "usr": "s:s26ExpressibleByStringLiteralP"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "ArrayLiteralConvertible",
-      "printedName": "ArrayLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s23ArrayLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ExpressibleByArrayLiteral",
-          "printedName": "ExpressibleByArrayLiteral",
-          "usr": "s:s25ExpressibleByArrayLiteralP"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "DictionaryLiteralConvertible",
-      "printedName": "DictionaryLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s28DictionaryLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ExpressibleByDictionaryLiteral",
-          "printedName": "ExpressibleByDictionaryLiteral",
-          "usr": "s:s30ExpressibleByDictionaryLiteralP"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "StringInterpolationConvertible",
-      "printedName": "StringInterpolationConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s30StringInterpolationConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNameAlias",
-          "name": "ExpressibleByStringInterpolation",
-          "printedName": "ExpressibleByStringInterpolation",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "_ExpressibleByStringInterpolation",
-              "printedName": "_ExpressibleByStringInterpolation",
-              "usr": "s:s33_ExpressibleByStringInterpolationP"
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "BitwiseOperations",
-      "printedName": "BitwiseOperations",
-      "declKind": "TypeAlias",
-      "usr": "s:s17BitwiseOperationsa",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "_BitwiseOperations",
-          "printedName": "_BitwiseOperations",
-          "usr": "s:s18_BitwiseOperationsP"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "Integer",
-      "printedName": "Integer",
-      "declKind": "TypeAlias",
-      "usr": "s:s7Integera",
-      "location": "",
+      "declKind": "Enum",
+      "usr": "s:s7UnicodeO",
       "moduleName": "Swift",
       "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "BinaryInteger",
-          "printedName": "BinaryInteger",
-          "usr": "s:Sz"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "IntegerArithmetic",
-      "printedName": "IntegerArithmetic",
-      "declKind": "TypeAlias",
-      "usr": "s:s17IntegerArithmetica",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "BinaryInteger",
-          "printedName": "BinaryInteger",
-          "usr": "s:Sz"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "SignedNumber",
-      "printedName": "SignedNumber",
-      "declKind": "TypeAlias",
-      "usr": "s:s12SignedNumbera",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ProtocolComposition",
-          "printedName": "Comparable & SignedNumeric"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "AbsoluteValuable",
-      "printedName": "AbsoluteValuable",
-      "declKind": "TypeAlias",
-      "usr": "s:s16AbsoluteValuablea",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ProtocolComposition",
-          "printedName": "Comparable & SignedNumeric"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "UTF8",
-      "printedName": "UTF8",
-      "declKind": "TypeAlias",
-      "usr": "s:s4UTF8a",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "UTF8",
-          "printedName": "Unicode.UTF8",
-          "usr": "s:s7UnicodeO4UTF8O"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "UTF16",
-      "printedName": "UTF16",
-      "declKind": "TypeAlias",
-      "usr": "s:s5UTF16a",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "UTF16",
-          "printedName": "Unicode.UTF16",
-          "usr": "s:s7UnicodeO5UTF16O"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "UTF32",
-      "printedName": "UTF32",
-      "declKind": "TypeAlias",
-      "usr": "s:s5UTF32a",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "UTF32",
-          "printedName": "Unicode.UTF32",
-          "usr": "s:s7UnicodeO5UTF32O"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "UnicodeScalar",
-      "printedName": "UnicodeScalar",
-      "declKind": "TypeAlias",
-      "usr": "s:Sc",
-      "location": "",
-      "moduleName": "Swift",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Scalar",
-          "printedName": "Unicode.Scalar",
-          "usr": "s:s7UnicodeO6ScalarV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "UnsafeBufferPointerIterator",
-      "printedName": "UnsafeBufferPointerIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s27UnsafeBufferPointerIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Iterator",
-          "printedName": "UnsafeBufferPointer<T>.Iterator",
-          "usr": "s:SR8IteratorV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "UnsafeRawBufferPointerIterator",
-      "printedName": "UnsafeRawBufferPointerIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s30UnsafeRawBufferPointerIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Iterator",
-          "printedName": "UnsafeBufferPointer<T>.Iterator",
-          "usr": "s:SR8IteratorV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "UnsafeMutableRawBufferPointerIterator",
-      "printedName": "UnsafeMutableRawBufferPointerIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s37UnsafeMutableRawBufferPointerIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Iterator",
-          "printedName": "UnsafeBufferPointer<T>.Iterator",
-          "usr": "s:SR8IteratorV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "PlaygroundQuickLook",
-      "printedName": "PlaygroundQuickLook",
-      "declKind": "TypeAlias",
-      "usr": "s:s19PlaygroundQuickLooka",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "_PlaygroundQuickLook",
-          "printedName": "_PlaygroundQuickLook",
-          "usr": "s:s20_PlaygroundQuickLookO"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "CustomPlaygroundQuickLookable",
-      "printedName": "CustomPlaygroundQuickLookable",
-      "declKind": "TypeAlias",
-      "usr": "s:s29CustomPlaygroundQuickLookablea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "_CustomPlaygroundQuickLookable",
-          "printedName": "_CustomPlaygroundQuickLookable",
-          "usr": "s:s30_CustomPlaygroundQuickLookableP"
-        }
+        "Frozen"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "CollectionOfOne",
       "printedName": "CollectionOfOne",
-      "declKind": "Struct",
-      "usr": "s:s15CollectionOfOneV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "RandomAccessCollection",
-        "MutableCollection",
-        "BidirectionalCollection",
-        "Collection",
-        "Sequence",
-        "CustomDebugStringConvertible",
-        "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s15CollectionOfOneVyAByxGxcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "kind": "Var",
+          "name": "_element",
+          "printedName": "_element",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "CollectionOfOne",
-              "printedName": "CollectionOfOne<Element>",
-              "usr": "s:s15CollectionOfOneV",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15CollectionOfOneV8_elementxvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15CollectionOfOneV8_elementxvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "CollectionOfOne",
+              "printedName": "CollectionOfOne<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s15CollectionOfOneV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Element"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s15CollectionOfOneVyAByxGxcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s15CollectionOfOneV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "conformingProtocols": [
-            "IteratorProtocol"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "Function",
-              "name": "next",
-              "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s15CollectionOfOneV8IteratorV4nextxSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
+              "kind": "Var",
+              "name": "_elements",
+              "printedName": "_elements",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Element?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Element"
+                      "printedName": "τ_0_0"
                     }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<τ_0_0>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s15CollectionOfOneV8IteratorV9_elementsxSgvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s15CollectionOfOneV8IteratorV9_elementsxSgvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "HasInitialValue",
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
             },
             {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s15CollectionOfOneV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
+              "kind": "Function",
+              "name": "next",
+              "printedName": "next()",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s15CollectionOfOneV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s15CollectionOfOneV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Int>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s15CollectionOfOneV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<CollectionOfOne<Element>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "CollectionOfOne",
-                  "printedName": "CollectionOfOne<Element>",
-                  "usr": "s:s15CollectionOfOneV",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Element"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s15CollectionOfOneV8IteratorV4nextxSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s15CollectionOfOneV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s15CollectionOfOneV10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "CollectionOfOne<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15CollectionOfOneV10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "CollectionOfOne<Element>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s15CollectionOfOneV8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "CollectionOfOne<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15CollectionOfOneV8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "CollectionOfOne<Element>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s15CollectionOfOneV5index5afterS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "CollectionOfOne<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "CollectionOfOne<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s15CollectionOfOneV5index6beforeS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "CollectionOfOne<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "CollectionOfOne<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "makeIterator",
-          "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s15CollectionOfOneV12makeIteratorAB0E0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Iterator",
-              "printedName": "CollectionOfOne<Element>.Iterator",
-              "usr": "s:s15CollectionOfOneV8IteratorV"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "count",
-          "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s15CollectionOfOneV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -115942,11 +120518,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15CollectionOfOneV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -115954,35 +120525,244 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15CollectionOfOneV10startIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15CollectionOfOneV10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s15CollectionOfOneV7Elementa",
-          "location": "",
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15CollectionOfOneV8endIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15CollectionOfOneV8endIndexSivp",
           "moduleName": "Swift",
-          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15CollectionOfOneV5index5afterS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15CollectionOfOneV5index6beforeS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "makeIterator",
+          "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Iterator",
+              "printedName": "CollectionOfOne<τ_0_0>.Iterator",
+              "usr": "s:s15CollectionOfOneV8IteratorV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15CollectionOfOneV12makeIteratorAB0E0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Element"
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s15CollectionOfOneVyxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<CollectionOfOne<τ_0_0>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "CollectionOfOne",
+                  "printedName": "CollectionOfOne<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:s15CollectionOfOneV"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s15CollectionOfOneVys5SliceVyAByxGGSnySiGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Var",
+          "name": "count",
+          "printedName": "count",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15CollectionOfOneV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15CollectionOfOneV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s15CollectionOfOneV16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -115994,11 +120774,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15CollectionOfOneV16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -116006,18 +120781,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15CollectionOfOneV16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s15CollectionOfOneV16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s15CollectionOfOneV12customMirrors0E0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -116029,11 +120807,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15CollectionOfOneV12customMirrors0E0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -116041,112 +120814,166 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15CollectionOfOneV12customMirrors0E0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s15CollectionOfOneV12customMirrors0E0Vvp",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s15CollectionOfOneV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "RandomAccessCollection",
+        "MutableCollection",
+        "BidirectionalCollection",
+        "Collection",
+        "Sequence",
+        "CustomDebugStringConvertible",
+        "CustomReflectable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AnyIterator",
       "printedName": "AnyIterator",
-      "declKind": "Struct",
-      "usr": "s:s11AnyIteratorV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "IteratorProtocol",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s11AnyIteratorVyAByxGqd__c7ElementQyd__RszStRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, I where Element == I.Element, I : IteratorProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "kind": "Var",
+          "name": "_box",
+          "printedName": "_box",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "AnyIterator",
-              "printedName": "AnyIterator<Element>",
-              "usr": "s:s11AnyIteratorV",
+              "name": "_AnyIteratorBoxBase",
+              "printedName": "_AnyIteratorBoxBase<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "usr": "s:s19_AnyIteratorBoxBaseC"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_AnyIteratorBoxBase",
+                  "printedName": "_AnyIteratorBoxBase<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:s19_AnyIteratorBoxBaseC"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11AnyIteratorV4_boxs01_aB7BoxBaseCyxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s11AnyIteratorV4_boxs01_aB7BoxBaseCyxGvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIterator",
+              "printedName": "AnyIterator<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s11AnyIteratorV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "I"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s11AnyIteratorVyAByxGqd__c7ElementQyd__RszStRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : IteratorProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s11AnyIteratorVyAByxGxSgyccfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyIterator",
-              "printedName": "AnyIterator<Element>",
-              "usr": "s:s11AnyIteratorV",
+              "printedName": "AnyIterator<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s11AnyIteratorV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "() -> AnyIterator<Element>.Element?",
+              "printedName": "() -> Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "AnyIterator<Element>.Element?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<τ_0_0>",
                   "children": [
                     {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "AnyIterator<Element>.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_0"
-                        }
-                      ]
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -116155,156 +120982,146 @@
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s11AnyIteratorVyAByxGxSgyccfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s11AnyIteratorV4nextxSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s11AnyIteratorV7Elementa",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnyIteratorV4nextxSgyF",
           "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s11AnyIteratorV0B0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyIterator",
-              "printedName": "AnyIterator<Element>",
-              "usr": "s:s11AnyIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s11AnyIteratorV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnySequence",
-              "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s11AnyIteratorV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol",
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AnySequence",
       "printedName": "AnySequence",
-      "declKind": "Struct",
-      "usr": "s:s11AnySequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
+          "kind": "Var",
+          "name": "_box",
+          "printedName": "_box",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "_AnySequenceBox",
+              "printedName": "_AnySequenceBox<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s15_AnySequenceBoxC"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_AnySequenceBox",
+                  "printedName": "_AnySequenceBox<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:s15_AnySequenceBoxC"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11AnySequenceV4_boxs01_aB3BoxCyxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s11AnySequenceV4_boxs01_aB3BoxCyxGvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s11AnySequenceVyAByxGqd__ycc7ElementQyd__RszStRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, I where Element == I.Element, I : IteratorProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
-              "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
+              "printedName": "AnySequence<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "() -> I",
+              "printedName": "() -> τ_1_0",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "I"
+                  "printedName": "τ_1_0"
                 },
                 {
                   "kind": "TypeNominal",
@@ -116313,155 +121130,79 @@
                 }
               ]
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s11AnySequenceV8Iteratora",
-          "location": "",
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s11AnySequenceVyAByxGqd__ycc7ElementQyd__RszStRd__lufc",
           "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyIterator",
-              "printedName": "AnyIterator<Element>",
-              "usr": "s:s11AnyIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : IteratorProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s11AnySequenceVyAByxGqd__c7ElementQyd__RszSTRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
-              "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
+              "printedName": "AnySequence<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "S"
+              "printedName": "τ_1_0"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s11AnySequenceV7Elementa",
-          "location": "",
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s11AnySequenceVyAByxGqd__c7ElementQyd__RszSTRd__lufc",
           "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s11AnySequenceV03SubB0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnySequence",
-              "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV12makeIterators0aD0VyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable",
-            "Inline"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Iterator",
-              "printedName": "AnySequence<Element>.Iterator",
+              "kind": "TypeNominal",
+              "name": "AnyIterator",
+              "printedName": "AnyIterator<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "AnyIterator",
-                  "printedName": "AnyIterator<τ_0_0>",
-                  "usr": "s:s11AnyIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s11AnyIteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV12makeIterators0aD0VyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable",
+            "Inline"
           ]
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s11AnySequenceV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -116473,11 +121214,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11AnySequenceV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -116485,102 +121221,91 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11AnySequenceV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s11AnySequenceV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV3mapySayqd__Gqd__xKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, T>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[T]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> T",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> τ_1_0",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV3mapySayqd__Gqd__xKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV6filterySayxGSbxKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Element]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -116590,34 +121315,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV6filterySayxGSbxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "forEach",
           "printedName": "forEach(_:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV7forEachyyyxKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -116627,74 +121347,56 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> ()",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
+                  "kind": "TypeNominal",
                   "name": "Void",
-                  "printedName": "Void",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Void",
-                      "printedName": "()"
-                    }
-                  ]
+                  "printedName": "()"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV7forEachyyyxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV4drop5whileAByxGSbxKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
-              "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
+              "printedName": "AnySequence<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -116704,45 +121406,42 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV4drop5whileAByxGSbxKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV9dropFirstyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
-              "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
+              "printedName": "AnySequence<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
@@ -116750,33 +121449,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV9dropFirstyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV8dropLastyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
-              "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
+              "printedName": "AnySequence<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
@@ -116784,43 +121482,37 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV8dropLastyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV6prefix5whileAByxGSbxKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
-              "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
+              "printedName": "AnySequence<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -116830,45 +121522,42 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV6prefix5whileAByxGSbxKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(_:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV6prefixyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
-              "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
+              "printedName": "AnySequence<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
@@ -116876,33 +121565,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV6prefixyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV6suffixyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
-              "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
+              "printedName": "AnySequence<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
@@ -116910,43 +121598,40 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV6suffixyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(maxSplits:omittingEmptySubsequences:whereSeparator:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAByxGGSi_S2bxKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[AnySequence<Element>]",
-              "usr": "s:Sa",
+              "printedName": "Array<AnySequence<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnySequence",
-                  "printedName": "AnySequence<Element>",
-                  "usr": "s:s11AnySequenceV",
+                  "printedName": "AnySequence<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Element"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s11AnySequenceV"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -116965,10 +121650,7 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -116978,50 +121660,89 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAByxGGSi_S2bxKXEtKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s11AnySequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AnyIndex",
       "printedName": "AnyIndex",
-      "declKind": "Struct",
-      "usr": "s:s8AnyIndexV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Comparable",
-        "Equatable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
+          "kind": "Var",
+          "name": "_box",
+          "printedName": "_box",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "_AnyIndexBox",
+              "printedName": "_AnyIndexBox",
+              "usr": "s:s12_AnyIndexBoxP"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_AnyIndexBox",
+                  "printedName": "_AnyIndexBox",
+                  "usr": "s:s12_AnyIndexBoxP"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s8AnyIndexV4_boxs01_aB3Box_pvg",
+              "moduleName": "Swift",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s8AnyIndexV4_boxs01_aB3Box_pvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s8AnyIndexVyABxcSLRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<BaseIndex where BaseIndex : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -117032,77 +121753,189 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "BaseIndex"
+              "printedName": "τ_0_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s8AnyIndexVyABxcSLRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : Comparable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s8AnyIndexV2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s8AnyIndexV1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s8AnyIndexV",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Comparable",
+        "Equatable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AnyCollection",
       "printedName": "AnyCollection",
-      "declKind": "Struct",
-      "usr": "s:s13AnyCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "Collection",
-        "Sequence",
-        "_AnyCollectionProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "Function",
-          "name": "makeIterator",
-          "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV12makeIterators0aD0VyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable",
-            "Inline"
-          ],
+          "kind": "Var",
+          "name": "_box",
+          "printedName": "_box",
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Iterator",
-              "printedName": "AnyCollection<Element>.Iterator",
+              "kind": "TypeNominal",
+              "name": "_AnyCollectionBox",
+              "printedName": "_AnyCollectionBox<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "AnyIterator",
-                  "printedName": "AnyIterator<τ_0_0>",
-                  "usr": "s:s11AnyIteratorV",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s17_AnyCollectionBoxC"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_AnyCollectionBox",
+                  "printedName": "_AnyCollectionBox<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s17_AnyCollectionBoxC"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13AnyCollectionV4_boxs01_aB3BoxCyxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13AnyCollectionV4_boxs01_aB3BoxCyxGvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Function",
+          "name": "makeIterator",
+          "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIterator",
+              "printedName": "AnyIterator<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s11AnyIteratorV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV12makeIterators0aD0VyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable",
+            "Inline"
           ]
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s13AnyCollectionV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -117114,11 +121947,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13AnyCollectionV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -117126,116 +121954,91 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13AnyCollectionV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13AnyCollectionV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV3mapySayqd__Gqd__xKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, T>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[T]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(AnyCollection<Element>.Element) throws -> T",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> τ_1_0",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(AnyCollection<Element>.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "AnyCollection<Element>.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_0"
-                        }
-                      ]
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV3mapySayqd__Gqd__xKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV6filterySayxGSbxKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[AnyCollection<Element>.Element]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "AnyCollection<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(AnyCollection<Element>.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -117245,41 +122048,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(AnyCollection<Element>.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "AnyCollection<Element>.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_0"
-                        }
-                      ]
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV6filterySayxGSbxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "forEach",
           "printedName": "forEach(_:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV7forEachyyyxKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -117289,88 +122080,56 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(AnyCollection<Element>.Element) throws -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> ()",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
+                  "kind": "TypeNominal",
                   "name": "Void",
-                  "printedName": "Void",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Void",
-                      "printedName": "()"
-                    }
-                  ]
+                  "printedName": "()"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(AnyCollection<Element>.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "AnyCollection<Element>.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_0"
-                        }
-                      ]
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV7forEachyyyxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV4drop5whileAByxGSbxKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
-              "printedName": "AnyCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s13AnyCollectionV",
+              "printedName": "AnyCollection<τ_0_0>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "AnyCollection<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(AnyCollection<Element>.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -117380,59 +122139,42 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(AnyCollection<Element>.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "AnyCollection<Element>.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_0"
-                        }
-                      ]
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV4drop5whileAByxGSbxKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV9dropFirstyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
-              "printedName": "AnyCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s13AnyCollectionV",
+              "printedName": "AnyCollection<τ_0_0>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "AnyCollection<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -117440,40 +122182,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV9dropFirstyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV8dropLastyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
-              "printedName": "AnyCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s13AnyCollectionV",
+              "printedName": "AnyCollection<τ_0_0>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "AnyCollection<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -117481,50 +122215,37 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV8dropLastyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV6prefix5whileAByxGSbxKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
-              "printedName": "AnyCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s13AnyCollectionV",
+              "printedName": "AnyCollection<τ_0_0>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "AnyCollection<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(AnyCollection<Element>.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -117534,59 +122255,42 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(AnyCollection<Element>.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "AnyCollection<Element>.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_0"
-                        }
-                      ]
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV6prefix5whileAByxGSbxKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(_:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV6prefixyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
-              "printedName": "AnyCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s13AnyCollectionV",
+              "printedName": "AnyCollection<τ_0_0>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "AnyCollection<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -117594,40 +122298,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV6prefixyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV6suffixyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
-              "printedName": "AnyCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s13AnyCollectionV",
+              "printedName": "AnyCollection<τ_0_0>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "AnyCollection<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -117635,50 +122331,40 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV6suffixyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(maxSplits:omittingEmptySubsequences:whereSeparator:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAByxGGSi_S2bxKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[AnyCollection<AnyCollection<Element>.Element>]",
-              "usr": "s:Sa",
+              "printedName": "Array<AnyCollection<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnyCollection",
-                  "printedName": "AnyCollection<AnyCollection<Element>.Element>",
-                  "usr": "s:s13AnyCollectionV",
+                  "printedName": "AnyCollection<τ_0_0>",
                   "children": [
                     {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "AnyCollection<Element>.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_0"
-                        }
-                      ]
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s13AnyCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -117697,10 +122383,7 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(AnyCollection<Element>.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -117710,387 +122393,256 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(AnyCollection<Element>.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "AnyCollection<Element>.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_0"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s13AnyCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DefaultIndices",
-              "printedName": "DefaultIndices<AnyCollection<Element>>",
-              "usr": "s:SI",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyCollection",
-                  "printedName": "AnyCollection<Element>",
-                  "usr": "s:s13AnyCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s13AnyCollectionV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyIterator",
-              "printedName": "AnyIterator<Element>",
-              "usr": "s:s11AnyIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s13AnyCollectionV5Indexa",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAByxGGSi_S2bxKXEtKF",
           "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyIndex",
-              "printedName": "AnyIndex",
-              "usr": "s:s8AnyIndexV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s13AnyCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyCollection",
-              "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "AnyCollection",
+              "printedName": "AnyCollection<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s13AnyCollectionV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s13AnyCollectionVyAByxGqd__c7ElementQyd__RszSlRd__lufc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Element, C where Element == C.Element, C : Collection>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : Collection>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyCollection",
-              "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "C"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "AnyCollection",
+              "printedName": "AnyCollection<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s13AnyCollectionV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyCollection",
+              "printedName": "AnyCollection<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s13AnyCollectionV"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s13AnyCollectionVyAByxGACcfc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Element>",
+          "genericSig": "<τ_0_0>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyCollection",
-              "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "AnyCollection",
-              "printedName": "AnyCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s13AnyCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "AnyCollection<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13AnyCollectionVyAByxGqd__c7ElementQyd__RszSKRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, C where Element == C.Element, C : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
-              "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
+              "printedName": "AnyCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "C"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13AnyCollectionVyAByxGqd__c7ElementQyd__RszSKRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13AnyCollectionVyAByxGs0a13BidirectionalB0VyxGcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
-              "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
+              "printedName": "AnyCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
-              "printedName": "AnyBidirectionalCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
+              "printedName": "AnyBidirectionalCollection<τ_0_0>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "AnyCollection<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13AnyCollectionVyAByxGs0a13BidirectionalB0VyxGcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13AnyCollectionVyAByxGqd__c7ElementQyd__RszSkRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, C where Element == C.Element, C : RandomAccessCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
-              "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
+              "printedName": "AnyCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "C"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13AnyCollectionVyAByxGqd__c7ElementQyd__RszSkRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : RandomAccessCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13AnyCollectionVyAByxGs0a12RandomAccessB0VyxGcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
-              "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
+              "printedName": "AnyCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
-              "printedName": "AnyRandomAccessCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
+              "printedName": "AnyRandomAccessCollection<τ_0_0>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "AnyCollection<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13AnyCollectionVyAByxGs0a12RandomAccessB0VyxGcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s13AnyCollectionV10startIndexs0aD0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyCollection<Element>.Index",
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -118098,51 +122650,35 @@
                   "printedName": "AnyIndex",
                   "usr": "s:s8AnyIndexV"
                 }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
+              ],
               "declKind": "Accessor",
               "usr": "s:s13AnyCollectionV10startIndexs0aD0Vvg",
-              "location": "",
               "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "AnyCollection<Element>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "AnyIndex",
-                      "printedName": "AnyIndex",
-                      "usr": "s:s8AnyIndexV"
-                    }
-                  ]
-                }
-              ]
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13AnyCollectionV10startIndexs0aD0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s13AnyCollectionV8endIndexs0aD0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyCollection<Element>.Index",
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -118150,88 +122686,116 @@
                   "printedName": "AnyIndex",
                   "usr": "s:s8AnyIndexV"
                 }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
+              ],
               "declKind": "Accessor",
               "usr": "s:s13AnyCollectionV8endIndexs0aD0Vvg",
-              "location": "",
               "moduleName": "Swift",
-              "genericSig": "<Element>",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13AnyCollectionV8endIndexs0aD0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s13AnyCollectionVyxs0A5IndexVcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "AnyCollection",
+              "printedName": "AnyCollection<τ_0_0>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "AnyCollection<Element>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "AnyIndex",
-                      "printedName": "AnyIndex",
-                      "usr": "s:s8AnyIndexV"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<AnyIndex>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "AnyIndex",
+                  "printedName": "AnyIndex",
+                  "usr": "s:s8AnyIndexV"
+                }
+              ],
+              "usr": "s:Sn"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s13AnyCollectionVyAByxGSnys0A5IndexVGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV5index5afters0A5IndexVAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV5index5afters0A5IndexVAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV9formIndex5afterys0aD0Vz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -118239,58 +122803,36 @@
               "printedName": "()"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV9formIndex5afterys0aD0Vz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV5index_8offsetBys0A5IndexVAF_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
               "kind": "TypeNominal",
@@ -118298,46 +122840,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV5index_8offsetBys0A5IndexVAF_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV5index_8offsetBy07limitedE0s0A5IndexVSgAG_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "AnyCollection<Element>.Index?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "AnyCollection<Element>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "AnyIndex",
-                      "printedName": "AnyIndex",
-                      "usr": "s:s8AnyIndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyCollection<Element>.Index",
+              "printedName": "Optional<AnyIndex>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -118345,7 +122865,14 @@
                   "printedName": "AnyIndex",
                   "usr": "s:s8AnyIndexV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
               "kind": "TypeNominal",
@@ -118354,32 +122881,24 @@
               "usr": "s:Si"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV5index_8offsetBy07limitedE0s0A5IndexVSgAG_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV9formIndex_8offsetByys0aD0Vz_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -118387,17 +122906,10 @@
               "printedName": "()"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
               "kind": "TypeNominal",
@@ -118405,20 +122917,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV9formIndex_8offsetByys0aD0Vz_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV9formIndex_8offsetBy07limitedF0Sbs0aD0Vz_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -118427,17 +122938,10 @@
               "usr": "s:Sb"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
               "kind": "TypeNominal",
@@ -118446,32 +122950,24 @@
               "usr": "s:Si"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV9formIndex_8offsetBy07limitedF0Sbs0aD0Vz_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV8distance4from2toSis0A5IndexV_AGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -118480,44 +122976,30 @@
               "usr": "s:Si"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV8distance4from2toSis0A5IndexV_AGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s13AnyCollectionV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -118529,11 +123011,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13AnyCollectionV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -118541,147 +123018,180 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13AnyCollectionV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13AnyCollectionV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "first",
           "printedName": "first",
-          "declKind": "Var",
-          "usr": "s:s13AnyCollectionV5firstxSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13AnyCollectionV5firstxSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Element?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Element"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13AnyCollectionV5firstxSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s13AnyCollectionV7Elementa",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s13AnyCollectionV5firstxSgvp",
           "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s13AnyCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Collection",
+        "Sequence",
+        "_AnyCollectionProtocol"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AnyBidirectionalCollection",
       "printedName": "AnyBidirectionalCollection",
-      "declKind": "Struct",
-      "usr": "s:s26AnyBidirectionalCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "BidirectionalCollection",
-        "Collection",
-        "Sequence",
-        "_AnyCollectionProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "Function",
-          "name": "makeIterator",
-          "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV12makeIterators0aE0VyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable",
-            "Inline"
-          ],
+          "kind": "Var",
+          "name": "_box",
+          "printedName": "_box",
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Iterator",
-              "printedName": "AnyBidirectionalCollection<Element>.Iterator",
+              "kind": "TypeNominal",
+              "name": "_AnyBidirectionalCollectionBox",
+              "printedName": "_AnyBidirectionalCollectionBox<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "AnyIterator",
-                  "printedName": "AnyIterator<τ_0_0>",
-                  "usr": "s:s11AnyIteratorV",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s30_AnyBidirectionalCollectionBoxC"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_AnyBidirectionalCollectionBox",
+                  "printedName": "_AnyBidirectionalCollectionBox<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s30_AnyBidirectionalCollectionBoxC"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s26AnyBidirectionalCollectionV4_boxs01_abC3BoxCyxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s26AnyBidirectionalCollectionV4_boxs01_abC3BoxCyxGvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Function",
+          "name": "makeIterator",
+          "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIterator",
+              "printedName": "AnyIterator<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s11AnyIteratorV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV12makeIterators0aE0VyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable",
+            "Inline"
           ]
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s26AnyBidirectionalCollectionV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -118693,11 +123203,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s26AnyBidirectionalCollectionV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -118705,102 +123210,91 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s26AnyBidirectionalCollectionV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s26AnyBidirectionalCollectionV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV3mapySayqd__Gqd__xKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, T>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[T]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> T",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> τ_1_0",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV3mapySayqd__Gqd__xKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV6filterySayxGSbxKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Element]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -118810,34 +123304,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV6filterySayxGSbxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "forEach",
           "printedName": "forEach(_:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV7forEachyyyxKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -118847,74 +123336,56 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> ()",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
+                  "kind": "TypeNominal",
                   "name": "Void",
-                  "printedName": "Void",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Void",
-                      "printedName": "()"
-                    }
-                  ]
+                  "printedName": "()"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV7forEachyyyxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV4drop5whileAByxGSbxKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
-              "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
+              "printedName": "AnyBidirectionalCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -118924,45 +123395,42 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV4drop5whileAByxGSbxKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV9dropFirstyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
-              "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
+              "printedName": "AnyBidirectionalCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -118970,33 +123438,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV9dropFirstyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV8dropLastyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
-              "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
+              "printedName": "AnyBidirectionalCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -119004,43 +123471,37 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV8dropLastyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV6prefix5whileAByxGSbxKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
-              "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
+              "printedName": "AnyBidirectionalCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -119050,45 +123511,42 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV6prefix5whileAByxGSbxKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(_:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV6prefixyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
-              "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
+              "printedName": "AnyBidirectionalCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -119096,33 +123554,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV6prefixyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV6suffixyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
-              "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
+              "printedName": "AnyBidirectionalCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -119130,43 +123587,40 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV6suffixyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(maxSplits:omittingEmptySubsequences:whereSeparator:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAByxGGSi_S2bxKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[AnyBidirectionalCollection<Element>]",
-              "usr": "s:Sa",
+              "printedName": "Array<AnyBidirectionalCollection<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnyBidirectionalCollection",
-                  "printedName": "AnyBidirectionalCollection<Element>",
-                  "usr": "s:s26AnyBidirectionalCollectionV",
+                  "printedName": "AnyBidirectionalCollection<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Element"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s26AnyBidirectionalCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -119185,10 +123639,7 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -119198,334 +123649,232 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s26AnyBidirectionalCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DefaultIndices",
-              "printedName": "DefaultIndices<AnyBidirectionalCollection<Element>>",
-              "usr": "s:SI",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyBidirectionalCollection",
-                  "printedName": "AnyBidirectionalCollection<Element>",
-                  "usr": "s:s26AnyBidirectionalCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s26AnyBidirectionalCollectionV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyIterator",
-              "printedName": "AnyIterator<Element>",
-              "usr": "s:s11AnyIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s26AnyBidirectionalCollectionV5Indexa",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAByxGGSi_S2bxKXEtKF",
           "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyIndex",
-              "printedName": "AnyIndex",
-              "usr": "s:s8AnyIndexV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s26AnyBidirectionalCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyBidirectionalCollection",
-              "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "AnyBidirectionalCollection",
+              "printedName": "AnyBidirectionalCollection<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_1_0"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s26AnyBidirectionalCollectionVyAByxGqd__c7ElementQyd__RszSKRd__lufc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Element, C where Element == C.Element, C : BidirectionalCollection>",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : BidirectionalCollection>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyBidirectionalCollection",
-              "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "C"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "AnyBidirectionalCollection",
+              "printedName": "AnyBidirectionalCollection<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyBidirectionalCollection",
+              "printedName": "AnyBidirectionalCollection<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s26AnyBidirectionalCollectionVyAByxGACcfc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Element>",
+          "genericSig": "<τ_0_0>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyBidirectionalCollection",
-              "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "AnyBidirectionalCollection",
-              "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s26AnyBidirectionalCollectionVyAByxGqd__c7ElementQyd__RszSkRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, C where Element == C.Element, C : RandomAccessCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
-              "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
+              "printedName": "AnyBidirectionalCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "C"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s26AnyBidirectionalCollectionVyAByxGqd__c7ElementQyd__RszSkRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : RandomAccessCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s26AnyBidirectionalCollectionVyAByxGs0a12RandomAccessC0VyxGcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
-              "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
+              "printedName": "AnyBidirectionalCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
-              "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
+              "printedName": "AnyRandomAccessCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s26AnyBidirectionalCollectionVyAByxGs0a12RandomAccessC0VyxGcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s26AnyBidirectionalCollectionVyAByxGSgs0aC0VyxGcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "AnyBidirectionalCollection<Element>?",
-              "usr": "s:Sq",
+              "printedName": "Optional<AnyBidirectionalCollection<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnyBidirectionalCollection",
-                  "printedName": "AnyBidirectionalCollection<Element>",
-                  "usr": "s:s26AnyBidirectionalCollectionV",
+                  "printedName": "AnyBidirectionalCollection<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Element"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s26AnyBidirectionalCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
-              "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
+              "printedName": "AnyCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s26AnyBidirectionalCollectionVyAByxGSgs0aC0VyxGcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s26AnyBidirectionalCollectionV10startIndexs0aE0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyBidirectionalCollection<Element>.Index",
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -119533,51 +123882,35 @@
                   "printedName": "AnyIndex",
                   "usr": "s:s8AnyIndexV"
                 }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
+              ],
               "declKind": "Accessor",
               "usr": "s:s26AnyBidirectionalCollectionV10startIndexs0aE0Vvg",
-              "location": "",
               "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "AnyBidirectionalCollection<Element>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "AnyIndex",
-                      "printedName": "AnyIndex",
-                      "usr": "s:s8AnyIndexV"
-                    }
-                  ]
-                }
-              ]
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s26AnyBidirectionalCollectionV10startIndexs0aE0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s26AnyBidirectionalCollectionV8endIndexs0aE0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyBidirectionalCollection<Element>.Index",
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -119585,88 +123918,116 @@
                   "printedName": "AnyIndex",
                   "usr": "s:s8AnyIndexV"
                 }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
+              ],
               "declKind": "Accessor",
               "usr": "s:s26AnyBidirectionalCollectionV8endIndexs0aE0Vvg",
-              "location": "",
               "moduleName": "Swift",
-              "genericSig": "<Element>",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s26AnyBidirectionalCollectionV8endIndexs0aE0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s26AnyBidirectionalCollectionVyxs0A5IndexVcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "AnyBidirectionalCollection",
+              "printedName": "AnyBidirectionalCollection<τ_0_0>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "AnyBidirectionalCollection<Element>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "AnyIndex",
-                      "printedName": "AnyIndex",
-                      "usr": "s:s8AnyIndexV"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<AnyIndex>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "AnyIndex",
+                  "printedName": "AnyIndex",
+                  "usr": "s:s8AnyIndexV"
+                }
+              ],
+              "usr": "s:Sn"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s26AnyBidirectionalCollectionVyAByxGSnys0A5IndexVGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV5index5afters0A5IndexVAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyBidirectionalCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyBidirectionalCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV5index5afters0A5IndexVAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV9formIndex5afterys0aE0Vz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -119674,58 +124035,36 @@
               "printedName": "()"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyBidirectionalCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV9formIndex5afterys0aE0Vz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV5index_8offsetBys0A5IndexVAF_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyBidirectionalCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyBidirectionalCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
               "kind": "TypeNominal",
@@ -119733,46 +124072,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV5index_8offsetBys0A5IndexVAF_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV5index_8offsetBy07limitedF0s0A5IndexVSgAG_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "AnyBidirectionalCollection<Element>.Index?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "AnyBidirectionalCollection<Element>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "AnyIndex",
-                      "printedName": "AnyIndex",
-                      "usr": "s:s8AnyIndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyBidirectionalCollection<Element>.Index",
+              "printedName": "Optional<AnyIndex>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -119780,7 +124097,14 @@
                   "printedName": "AnyIndex",
                   "usr": "s:s8AnyIndexV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
               "kind": "TypeNominal",
@@ -119789,32 +124113,24 @@
               "usr": "s:Si"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyBidirectionalCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV5index_8offsetBy07limitedF0s0A5IndexVSgAG_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV9formIndex_8offsetByys0aE0Vz_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -119822,17 +124138,10 @@
               "printedName": "()"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyBidirectionalCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
               "kind": "TypeNominal",
@@ -119840,20 +124149,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV9formIndex_8offsetByys0aE0Vz_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV9formIndex_8offsetBy07limitedG0Sbs0aE0Vz_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -119862,17 +124170,10 @@
               "usr": "s:Sb"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyBidirectionalCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
               "kind": "TypeNominal",
@@ -119881,32 +124182,24 @@
               "usr": "s:Si"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyBidirectionalCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV9formIndex_8offsetBy07limitedG0Sbs0aE0Vz_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV8distance4from2toSis0A5IndexV_AGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -119915,44 +124208,30 @@
               "usr": "s:Si"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyBidirectionalCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyBidirectionalCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV8distance4from2toSis0A5IndexV_AGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s26AnyBidirectionalCollectionV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -119964,11 +124243,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s26AnyBidirectionalCollectionV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -119976,115 +124250,100 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s26AnyBidirectionalCollectionV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s26AnyBidirectionalCollectionV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "first",
           "printedName": "first",
-          "declKind": "Var",
-          "usr": "s:s26AnyBidirectionalCollectionV5firstxSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s26AnyBidirectionalCollectionV5firstxSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Element?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Element"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s26AnyBidirectionalCollectionV5firstxSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s26AnyBidirectionalCollectionV5firstxSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV5index6befores0A5IndexVAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyBidirectionalCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyBidirectionalCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV5index6befores0A5IndexVAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV9formIndex6beforeys0aE0Vz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -120092,158 +124351,181 @@
               "printedName": "()"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyBidirectionalCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV9formIndex6beforeys0aE0Vz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "last",
           "printedName": "last",
-          "declKind": "Var",
-          "usr": "s:s26AnyBidirectionalCollectionV4lastxSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s26AnyBidirectionalCollectionV4lastxSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Element?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Element"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s26AnyBidirectionalCollectionV4lastxSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s26AnyBidirectionalCollectionV7Elementa",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s26AnyBidirectionalCollectionV4lastxSgvp",
           "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s26AnyBidirectionalCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "BidirectionalCollection",
+        "Collection",
+        "Sequence",
+        "_AnyCollectionProtocol"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AnyRandomAccessCollection",
       "printedName": "AnyRandomAccessCollection",
-      "declKind": "Struct",
-      "usr": "s:s25AnyRandomAccessCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "RandomAccessCollection",
-        "BidirectionalCollection",
-        "Collection",
-        "Sequence",
-        "_AnyCollectionProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "Function",
-          "name": "makeIterator",
-          "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV12makeIterators0aF0VyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable",
-            "Inline"
-          ],
+          "kind": "Var",
+          "name": "_box",
+          "printedName": "_box",
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Iterator",
-              "printedName": "AnyRandomAccessCollection<Element>.Iterator",
+              "kind": "TypeNominal",
+              "name": "_AnyRandomAccessCollectionBox",
+              "printedName": "_AnyRandomAccessCollectionBox<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "AnyIterator",
-                  "printedName": "AnyIterator<τ_0_0>",
-                  "usr": "s:s11AnyIteratorV",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s29_AnyRandomAccessCollectionBoxC"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_AnyRandomAccessCollectionBox",
+                  "printedName": "_AnyRandomAccessCollectionBox<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s29_AnyRandomAccessCollectionBoxC"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25AnyRandomAccessCollectionV4_boxs01_abcD3BoxCyxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s25AnyRandomAccessCollectionV4_boxs01_abcD3BoxCyxGvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Function",
+          "name": "makeIterator",
+          "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIterator",
+              "printedName": "AnyIterator<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:s11AnyIteratorV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV12makeIterators0aF0VyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable",
+            "Inline"
           ]
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s25AnyRandomAccessCollectionV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -120255,11 +124537,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s25AnyRandomAccessCollectionV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -120267,102 +124544,91 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25AnyRandomAccessCollectionV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s25AnyRandomAccessCollectionV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV3mapySayqd__Gqd__xKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, T>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[T]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_1_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> T",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> τ_1_0",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "T"
+                  "printedName": "τ_1_0"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV3mapySayqd__Gqd__xKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV6filterySayxGSbxKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Element]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -120372,34 +124638,29 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV6filterySayxGSbxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "forEach",
           "printedName": "forEach(_:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV7forEachyyyxKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -120409,74 +124670,56 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> ()",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
+                  "kind": "TypeNominal",
                   "name": "Void",
-                  "printedName": "Void",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Void",
-                      "printedName": "()"
-                    }
-                  ]
+                  "printedName": "()"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV7forEachyyyxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV4drop5whileAByxGSbxKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
-              "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
+              "printedName": "AnyRandomAccessCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -120486,45 +124729,42 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV4drop5whileAByxGSbxKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV9dropFirstyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
-              "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
+              "printedName": "AnyRandomAccessCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -120532,33 +124772,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV9dropFirstyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV8dropLastyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
-              "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
+              "printedName": "AnyRandomAccessCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -120566,43 +124805,37 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV8dropLastyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV6prefix5whileAByxGSbxKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
-              "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
+              "printedName": "AnyRandomAccessCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -120612,45 +124845,42 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV6prefix5whileAByxGSbxKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(_:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV6prefixyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
-              "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
+              "printedName": "AnyRandomAccessCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -120658,33 +124888,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV6prefixyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV6suffixyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
-              "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
+              "printedName": "AnyRandomAccessCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -120692,43 +124921,40 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV6suffixyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(maxSplits:omittingEmptySubsequences:whereSeparator:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAByxGGSi_S2bxKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[AnyRandomAccessCollection<Element>]",
-              "usr": "s:Sa",
+              "printedName": "Array<AnyRandomAccessCollection<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnyRandomAccessCollection",
-                  "printedName": "AnyRandomAccessCollection<Element>",
-                  "usr": "s:s25AnyRandomAccessCollectionV",
+                  "printedName": "AnyRandomAccessCollection<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Element"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s25AnyRandomAccessCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -120747,10 +124973,7 @@
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -120760,309 +124983,208 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s25AnyRandomAccessCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DefaultIndices",
-              "printedName": "DefaultIndices<AnyRandomAccessCollection<Element>>",
-              "usr": "s:SI",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyRandomAccessCollection",
-                  "printedName": "AnyRandomAccessCollection<Element>",
-                  "usr": "s:s25AnyRandomAccessCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s25AnyRandomAccessCollectionV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyIterator",
-              "printedName": "AnyIterator<Element>",
-              "usr": "s:s11AnyIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s25AnyRandomAccessCollectionV5Indexa",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAByxGGSi_S2bxKXEtKF",
           "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyIndex",
-              "printedName": "AnyIndex",
-              "usr": "s:s8AnyIndexV"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s25AnyRandomAccessCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyRandomAccessCollection",
-              "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s25AnyRandomAccessCollectionVyAByxGqd__c7ElementQyd__RszSkRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, C where Element == C.Element, C : RandomAccessCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
-              "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
+              "printedName": "AnyRandomAccessCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "C"
+              "printedName": "τ_1_0"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s25AnyRandomAccessCollectionVyAByxGqd__c7ElementQyd__RszSkRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_1_0 where τ_0_0 == τ_1_0.Element, τ_1_0 : RandomAccessCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s25AnyRandomAccessCollectionVyAByxGACcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
-              "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
+              "printedName": "AnyRandomAccessCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
-              "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
+              "printedName": "AnyRandomAccessCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s25AnyRandomAccessCollectionVyAByxGACcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s25AnyRandomAccessCollectionVyAByxGSgs0aD0VyxGcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "AnyRandomAccessCollection<Element>?",
-              "usr": "s:Sq",
+              "printedName": "Optional<AnyRandomAccessCollection<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnyRandomAccessCollection",
-                  "printedName": "AnyRandomAccessCollection<Element>",
-                  "usr": "s:s25AnyRandomAccessCollectionV",
+                  "printedName": "AnyRandomAccessCollection<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Element"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s25AnyRandomAccessCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
-              "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
+              "printedName": "AnyCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s25AnyRandomAccessCollectionVyAByxGSgs0aD0VyxGcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s25AnyRandomAccessCollectionVyAByxGSgs0a13BidirectionalD0VyxGcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "AnyRandomAccessCollection<Element>?",
-              "usr": "s:Sq",
+              "printedName": "Optional<AnyRandomAccessCollection<τ_0_0>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnyRandomAccessCollection",
-                  "printedName": "AnyRandomAccessCollection<Element>",
-                  "usr": "s:s25AnyRandomAccessCollectionV",
+                  "printedName": "AnyRandomAccessCollection<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Element"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s25AnyRandomAccessCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
-              "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
+              "printedName": "AnyBidirectionalCollection<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s25AnyRandomAccessCollectionVyAByxGSgs0a13BidirectionalD0VyxGcfc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s25AnyRandomAccessCollectionV10startIndexs0aF0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyRandomAccessCollection<Element>.Index",
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -121070,51 +125192,35 @@
                   "printedName": "AnyIndex",
                   "usr": "s:s8AnyIndexV"
                 }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
+              ],
               "declKind": "Accessor",
               "usr": "s:s25AnyRandomAccessCollectionV10startIndexs0aF0Vvg",
-              "location": "",
               "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "AnyRandomAccessCollection<Element>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "AnyIndex",
-                      "printedName": "AnyIndex",
-                      "usr": "s:s8AnyIndexV"
-                    }
-                  ]
-                }
-              ]
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s25AnyRandomAccessCollectionV10startIndexs0aF0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s25AnyRandomAccessCollectionV8endIndexs0aF0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyRandomAccessCollection<Element>.Index",
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -121122,88 +125228,116 @@
                   "printedName": "AnyIndex",
                   "usr": "s:s8AnyIndexV"
                 }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
+              ],
               "declKind": "Accessor",
               "usr": "s:s25AnyRandomAccessCollectionV8endIndexs0aF0Vvg",
-              "location": "",
               "moduleName": "Swift",
-              "genericSig": "<Element>",
+              "genericSig": "<τ_0_0>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s25AnyRandomAccessCollectionV8endIndexs0aF0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s25AnyRandomAccessCollectionVyxs0A5IndexVcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "AnyRandomAccessCollection",
+              "printedName": "AnyRandomAccessCollection<τ_0_0>",
               "children": [
                 {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "AnyRandomAccessCollection<Element>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "AnyIndex",
-                      "printedName": "AnyIndex",
-                      "usr": "s:s8AnyIndexV"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<AnyIndex>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "AnyIndex",
+                  "printedName": "AnyIndex",
+                  "usr": "s:s8AnyIndexV"
+                }
+              ],
+              "usr": "s:Sn"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s25AnyRandomAccessCollectionVyAByxGSnys0A5IndexVGcip",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV5index5afters0A5IndexVAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyRandomAccessCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyRandomAccessCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV5index5afters0A5IndexVAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV9formIndex5afterys0aF0Vz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -121211,58 +125345,36 @@
               "printedName": "()"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyRandomAccessCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV9formIndex5afterys0aF0Vz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV5index_8offsetBys0A5IndexVAF_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyRandomAccessCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyRandomAccessCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
               "kind": "TypeNominal",
@@ -121270,46 +125382,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV5index_8offsetBys0A5IndexVAF_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV5index_8offsetBy07limitedG0s0A5IndexVSgAG_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "AnyRandomAccessCollection<Element>.Index?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "AnyRandomAccessCollection<Element>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "AnyIndex",
-                      "printedName": "AnyIndex",
-                      "usr": "s:s8AnyIndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyRandomAccessCollection<Element>.Index",
+              "printedName": "Optional<AnyIndex>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -121317,7 +125407,14 @@
                   "printedName": "AnyIndex",
                   "usr": "s:s8AnyIndexV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
               "kind": "TypeNominal",
@@ -121326,32 +125423,24 @@
               "usr": "s:Si"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyRandomAccessCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV5index_8offsetBy07limitedG0s0A5IndexVSgAG_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV9formIndex_8offsetByys0aF0Vz_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -121359,17 +125448,10 @@
               "printedName": "()"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyRandomAccessCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
               "kind": "TypeNominal",
@@ -121377,20 +125459,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV9formIndex_8offsetByys0aF0Vz_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV9formIndex_8offsetBy07limitedH0Sbs0aF0Vz_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -121399,17 +125480,10 @@
               "usr": "s:Sb"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyRandomAccessCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
               "kind": "TypeNominal",
@@ -121418,32 +125492,24 @@
               "usr": "s:Si"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyRandomAccessCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV9formIndex_8offsetBy07limitedH0Sbs0aF0Vz_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV8distance4from2toSis0A5IndexV_AGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -121452,44 +125518,30 @@
               "usr": "s:Si"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyRandomAccessCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyRandomAccessCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV8distance4from2toSis0A5IndexV_AGtF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s25AnyRandomAccessCollectionV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -121501,11 +125553,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s25AnyRandomAccessCollectionV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -121513,115 +125560,100 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25AnyRandomAccessCollectionV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s25AnyRandomAccessCollectionV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "first",
           "printedName": "first",
-          "declKind": "Var",
-          "usr": "s:s25AnyRandomAccessCollectionV5firstxSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s25AnyRandomAccessCollectionV5firstxSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Element?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Element"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25AnyRandomAccessCollectionV5firstxSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s25AnyRandomAccessCollectionV5firstxSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV5index6befores0A5IndexVAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyRandomAccessCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyRandomAccessCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV5index6befores0A5IndexVAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV9formIndex6beforeys0aF0Vz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -121629,121 +125661,100 @@
               "printedName": "()"
             },
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "AnyRandomAccessCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "AnyIndex",
-                  "printedName": "AnyIndex",
-                  "usr": "s:s8AnyIndexV"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV9formIndex6beforeys0aF0Vz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "last",
           "printedName": "last",
-          "declKind": "Var",
-          "usr": "s:s25AnyRandomAccessCollectionV4lastxSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s25AnyRandomAccessCollectionV4lastxSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Element?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "Element"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25AnyRandomAccessCollectionV4lastxSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0>"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s25AnyRandomAccessCollectionV7Elementa",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s25AnyRandomAccessCollectionV4lastxSgvp",
           "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s25AnyRandomAccessCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "RandomAccessCollection",
+        "BidirectionalCollection",
+        "Collection",
+        "Sequence",
+        "_AnyCollectionProtocol"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Mirror",
       "printedName": "Mirror",
-      "declKind": "Struct",
-      "usr": "s:s6MirrorV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "CustomStringConvertible",
-        "CustomReflectable"
-      ],
       "children": [
         {
           "kind": "TypeDecl",
           "name": "AncestorRepresentation",
           "printedName": "AncestorRepresentation",
-          "declKind": "Enum",
-          "usr": "s:s6MirrorV22AncestorRepresentationO",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "Var",
               "name": "generated",
               "printedName": "generated",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV22AncestorRepresentationO9generatedyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -121758,36 +125769,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Mirror.AncestorRepresentation.Type)",
+                      "name": "Metatype",
+                      "printedName": "Mirror.AncestorRepresentation.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Mirror.AncestorRepresentation.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "AncestorRepresentation",
-                              "printedName": "Mirror.AncestorRepresentation",
-                              "usr": "s:s6MirrorV22AncestorRepresentationO"
-                            }
-                          ]
+                          "name": "AncestorRepresentation",
+                          "printedName": "Mirror.AncestorRepresentation",
+                          "usr": "s:s6MirrorV22AncestorRepresentationO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV22AncestorRepresentationO9generatedyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "customized",
               "printedName": "customized",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV22AncestorRepresentationO10customizedyAdByccADmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -121807,8 +125810,8 @@
                         },
                         {
                           "kind": "TypeFunc",
-                          "name": "Paren",
-                          "printedName": "(@escaping () -> Mirror)",
+                          "name": "Function",
+                          "printedName": "() -> Mirror",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -121827,36 +125830,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Mirror.AncestorRepresentation.Type)",
+                      "name": "Metatype",
+                      "printedName": "Mirror.AncestorRepresentation.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Mirror.AncestorRepresentation.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "AncestorRepresentation",
-                              "printedName": "Mirror.AncestorRepresentation",
-                              "usr": "s:s6MirrorV22AncestorRepresentationO"
-                            }
-                          ]
+                          "name": "AncestorRepresentation",
+                          "printedName": "Mirror.AncestorRepresentation",
+                          "usr": "s:s6MirrorV22AncestorRepresentationO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV22AncestorRepresentationO10customizedyAdByccADmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "suppressed",
               "printedName": "suppressed",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV22AncestorRepresentationO10suppressedyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -121871,38 +125866,33 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Mirror.AncestorRepresentation.Type)",
+                      "name": "Metatype",
+                      "printedName": "Mirror.AncestorRepresentation.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Mirror.AncestorRepresentation.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "AncestorRepresentation",
-                              "printedName": "Mirror.AncestorRepresentation",
-                              "usr": "s:s6MirrorV22AncestorRepresentationO"
-                            }
-                          ]
+                          "name": "AncestorRepresentation",
+                          "printedName": "Mirror.AncestorRepresentation",
+                          "usr": "s:s6MirrorV22AncestorRepresentationO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV22AncestorRepresentationO10suppressedyA2DmF",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Enum",
+          "usr": "s:s6MirrorV22AncestorRepresentationO",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(reflecting:)",
-          "declKind": "Constructor",
-          "usr": "s:s6MirrorV10reflectingAByp_tcfc",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -121915,118 +125905,20 @@
               "name": "ProtocolComposition",
               "printedName": "Any"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Child",
-          "printedName": "Child",
-          "declKind": "TypeAlias",
-          "usr": "s:s6MirrorV5Childa",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(label: String?, value: Any)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "String",
-                      "printedName": "String",
-                      "usr": "s:SS"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "ProtocolComposition",
-                  "printedName": "Any"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Children",
-          "printedName": "Children",
-          "declKind": "TypeAlias",
-          "usr": "s:s6MirrorV8Childrena",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyCollection",
-              "printedName": "AnyCollection<Mirror.Child>",
-              "usr": "s:s13AnyCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Child",
-                  "printedName": "Mirror.Child",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Tuple",
-                      "printedName": "(label: Optional<String>, value: Any)",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Optional",
-                          "printedName": "Optional<String>",
-                          "usr": "s:Sq",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "String",
-                              "printedName": "String",
-                              "usr": "s:SS"
-                            }
-                          ]
-                        },
-                        {
-                          "kind": "TypeNominal",
-                          "name": "ProtocolComposition",
-                          "printedName": "Any"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6MirrorV10reflectingAByp_tcfc",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeDecl",
           "name": "DisplayStyle",
           "printedName": "DisplayStyle",
-          "declKind": "Enum",
-          "usr": "s:s6MirrorV12DisplayStyleO",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "Equatable",
-            "Hashable"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "struct",
               "printedName": "struct",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV12DisplayStyleO6structyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -122041,36 +125933,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Mirror.DisplayStyle.Type)",
+                      "name": "Metatype",
+                      "printedName": "Mirror.DisplayStyle.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Mirror.DisplayStyle.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "DisplayStyle",
-                              "printedName": "Mirror.DisplayStyle",
-                              "usr": "s:s6MirrorV12DisplayStyleO"
-                            }
-                          ]
+                          "name": "DisplayStyle",
+                          "printedName": "Mirror.DisplayStyle",
+                          "usr": "s:s6MirrorV12DisplayStyleO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV12DisplayStyleO6structyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "class",
               "printedName": "class",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV12DisplayStyleO5classyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -122085,36 +125969,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Mirror.DisplayStyle.Type)",
+                      "name": "Metatype",
+                      "printedName": "Mirror.DisplayStyle.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Mirror.DisplayStyle.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "DisplayStyle",
-                              "printedName": "Mirror.DisplayStyle",
-                              "usr": "s:s6MirrorV12DisplayStyleO"
-                            }
-                          ]
+                          "name": "DisplayStyle",
+                          "printedName": "Mirror.DisplayStyle",
+                          "usr": "s:s6MirrorV12DisplayStyleO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV12DisplayStyleO5classyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "enum",
               "printedName": "enum",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV12DisplayStyleO4enumyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -122129,36 +126005,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Mirror.DisplayStyle.Type)",
+                      "name": "Metatype",
+                      "printedName": "Mirror.DisplayStyle.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Mirror.DisplayStyle.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "DisplayStyle",
-                              "printedName": "Mirror.DisplayStyle",
-                              "usr": "s:s6MirrorV12DisplayStyleO"
-                            }
-                          ]
+                          "name": "DisplayStyle",
+                          "printedName": "Mirror.DisplayStyle",
+                          "usr": "s:s6MirrorV12DisplayStyleO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV12DisplayStyleO4enumyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "tuple",
               "printedName": "tuple",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV12DisplayStyleO5tupleyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -122173,36 +126041,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Mirror.DisplayStyle.Type)",
+                      "name": "Metatype",
+                      "printedName": "Mirror.DisplayStyle.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Mirror.DisplayStyle.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "DisplayStyle",
-                              "printedName": "Mirror.DisplayStyle",
-                              "usr": "s:s6MirrorV12DisplayStyleO"
-                            }
-                          ]
+                          "name": "DisplayStyle",
+                          "printedName": "Mirror.DisplayStyle",
+                          "usr": "s:s6MirrorV12DisplayStyleO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV12DisplayStyleO5tupleyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "optional",
               "printedName": "optional",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV12DisplayStyleO8optionalyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -122217,36 +126077,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Mirror.DisplayStyle.Type)",
+                      "name": "Metatype",
+                      "printedName": "Mirror.DisplayStyle.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Mirror.DisplayStyle.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "DisplayStyle",
-                              "printedName": "Mirror.DisplayStyle",
-                              "usr": "s:s6MirrorV12DisplayStyleO"
-                            }
-                          ]
+                          "name": "DisplayStyle",
+                          "printedName": "Mirror.DisplayStyle",
+                          "usr": "s:s6MirrorV12DisplayStyleO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV12DisplayStyleO8optionalyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "collection",
               "printedName": "collection",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV12DisplayStyleO10collectionyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -122261,36 +126113,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Mirror.DisplayStyle.Type)",
+                      "name": "Metatype",
+                      "printedName": "Mirror.DisplayStyle.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Mirror.DisplayStyle.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "DisplayStyle",
-                              "printedName": "Mirror.DisplayStyle",
-                              "usr": "s:s6MirrorV12DisplayStyleO"
-                            }
-                          ]
+                          "name": "DisplayStyle",
+                          "printedName": "Mirror.DisplayStyle",
+                          "usr": "s:s6MirrorV12DisplayStyleO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV12DisplayStyleO10collectionyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "dictionary",
               "printedName": "dictionary",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV12DisplayStyleO10dictionaryyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -122305,36 +126149,28 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Mirror.DisplayStyle.Type)",
+                      "name": "Metatype",
+                      "printedName": "Mirror.DisplayStyle.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Mirror.DisplayStyle.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "DisplayStyle",
-                              "printedName": "Mirror.DisplayStyle",
-                              "usr": "s:s6MirrorV12DisplayStyleO"
-                            }
-                          ]
+                          "name": "DisplayStyle",
+                          "printedName": "Mirror.DisplayStyle",
+                          "usr": "s:s6MirrorV12DisplayStyleO"
                         }
                       ]
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV12DisplayStyleO10dictionaryyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "set",
               "printedName": "set",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV12DisplayStyleO3setyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -122349,36 +126185,61 @@
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Paren",
-                      "printedName": "(Mirror.DisplayStyle.Type)",
+                      "name": "Metatype",
+                      "printedName": "Mirror.DisplayStyle.Type",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Metatype",
-                          "printedName": "Mirror.DisplayStyle.Type",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "DisplayStyle",
-                              "printedName": "Mirror.DisplayStyle",
-                              "usr": "s:s6MirrorV12DisplayStyleO"
-                            }
-                          ]
+                          "name": "DisplayStyle",
+                          "printedName": "Mirror.DisplayStyle",
+                          "usr": "s:s6MirrorV12DisplayStyleO"
                         }
                       ]
                     }
                   ]
                 }
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV12DisplayStyleO3setyA2DmF",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DisplayStyle",
+                  "printedName": "Mirror.DisplayStyle",
+                  "usr": "s:s6MirrorV12DisplayStyleO"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DisplayStyle",
+                  "printedName": "Mirror.DisplayStyle",
+                  "usr": "s:s6MirrorV12DisplayStyleO"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s6MirrorV12DisplayStyleO2eeoiySbAD_ADtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "implicit": true,
+              "declAttributes": [
+                "Infix"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s6MirrorV12DisplayStyleO9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122390,10 +126251,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6MirrorV12DisplayStyleO9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -122401,18 +126258,22 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6MirrorV12DisplayStyleO9hashValueSivg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s6MirrorV12DisplayStyleO9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s6MirrorV12DisplayStyleO4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122425,19 +126286,25 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s6MirrorV12DisplayStyleO4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Enum",
+          "usr": "s:s6MirrorV12DisplayStyleO",
+          "moduleName": "Swift",
+          "conformingProtocols": [
+            "Equatable",
+            "Hashable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:children:displayStyle:ancestorRepresentation:)",
-          "declKind": "Constructor",
-          "usr": "s:s6MirrorV_8children12displayStyle22ancestorRepresentationABx_q_AB07DisplayD0OSgAB08AncestorF0OtcSlR_SSSg5label_yp5valuet7ElementRt_r0_lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Subject, C where C : Collection, C.Element == Mirror.Child>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -122448,19 +126315,17 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Subject"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "C"
+              "printedName": "τ_0_1"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Mirror.DisplayStyle?",
-              "hasDefaultArg": true,
-              "usr": "s:Sq",
+              "printedName": "Optional<Mirror.DisplayStyle>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122468,7 +126333,9 @@
                   "printedName": "Mirror.DisplayStyle",
                   "usr": "s:s6MirrorV12DisplayStyleO"
                 }
-              ]
+              ],
+              "hasDefaultArg": true,
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -122477,17 +126344,16 @@
               "hasDefaultArg": true,
               "usr": "s:s6MirrorV22AncestorRepresentationO"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6MirrorV_8children12displayStyle22ancestorRepresentationABx_q_AB07DisplayD0OSgAB08AncestorF0OtcSlR_SSSg5label_yp5valuet7ElementRt_r0_lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_1 : Collection, τ_0_1.Element == (label: Optional<String>, value: Any)>"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:unlabeledChildren:displayStyle:ancestorRepresentation:)",
-          "declKind": "Constructor",
-          "usr": "s:s6MirrorV_17unlabeledChildren12displayStyle22ancestorRepresentationABx_q_AB07DisplayE0OSgAB08AncestorG0OtcSlR_r0_lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Subject, C where C : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -122498,19 +126364,17 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Subject"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "C"
+              "printedName": "τ_0_1"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Mirror.DisplayStyle?",
-              "hasDefaultArg": true,
-              "usr": "s:Sq",
+              "printedName": "Optional<Mirror.DisplayStyle>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122518,7 +126382,9 @@
                   "printedName": "Mirror.DisplayStyle",
                   "usr": "s:s6MirrorV12DisplayStyleO"
                 }
-              ]
+              ],
+              "hasDefaultArg": true,
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -122527,17 +126393,16 @@
               "hasDefaultArg": true,
               "usr": "s:s6MirrorV22AncestorRepresentationO"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6MirrorV_17unlabeledChildren12displayStyle22ancestorRepresentationABx_q_AB07DisplayE0OSgAB08AncestorG0OtcSlR_r0_lufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_1 : Collection>"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:children:displayStyle:ancestorRepresentation:)",
-          "declKind": "Constructor",
-          "usr": "s:s6MirrorV_8children12displayStyle22ancestorRepresentationABx_s17DictionaryLiteralVySSypGAB07DisplayD0OSgAB08AncestorF0Otclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Subject>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -122548,13 +126413,12 @@
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Subject"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
-              "name": "DictionaryLiteral",
-              "printedName": "DictionaryLiteral<String, Any>",
-              "usr": "s:s17DictionaryLiteralV",
+              "name": "KeyValuePairs",
+              "printedName": "KeyValuePairs<String, Any>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122567,14 +126431,13 @@
                   "name": "ProtocolComposition",
                   "printedName": "Any"
                 }
-              ]
+              ],
+              "usr": "s:s13KeyValuePairsV"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Mirror.DisplayStyle?",
-              "hasDefaultArg": true,
-              "usr": "s:Sq",
+              "printedName": "Optional<Mirror.DisplayStyle>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122582,7 +126445,9 @@
                   "printedName": "Mirror.DisplayStyle",
                   "usr": "s:s6MirrorV12DisplayStyleO"
                 }
-              ]
+              ],
+              "hasDefaultArg": true,
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -122591,16 +126456,16 @@
               "hasDefaultArg": true,
               "usr": "s:s6MirrorV22AncestorRepresentationO"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6MirrorV_8children12displayStyle22ancestorRepresentationABx_s13KeyValuePairsVySSypGAB07DisplayD0OSgAB08AncestorF0Otclufc",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0>"
         },
         {
           "kind": "Var",
           "name": "subjectType",
           "printedName": "subjectType",
-          "declKind": "Var",
-          "usr": "s:s6MirrorV11subjectTypeypXpvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -122618,10 +126483,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6MirrorV11subjectTypeypXpvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122635,29 +126496,67 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6MirrorV11subjectTypeypXpvg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6MirrorV11subjectTypeypXpvp",
+          "moduleName": "Swift",
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Var",
           "name": "children",
           "printedName": "children",
-          "declKind": "Var",
-          "usr": "s:s6MirrorV8childrens13AnyCollectionVySSSg5label_yp5valuetGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Children",
-              "printedName": "Mirror.Children",
+              "kind": "TypeNominal",
+              "name": "AnyCollection",
+              "printedName": "AnyCollection<(label: Optional<String>, value: Any)>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(label: Optional<String>, value: Any)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<String>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "String",
+                          "printedName": "String",
+                          "usr": "s:SS"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "ProtocolComposition",
+                      "printedName": "Any"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:s13AnyCollectionV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnyCollection",
                   "printedName": "AnyCollection<(label: Optional<String>, value: Any)>",
-                  "usr": "s:s13AnyCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -122668,7 +126567,6 @@
                           "kind": "TypeNominal",
                           "name": "Optional",
                           "printedName": "Optional<String>",
-                          "usr": "s:Sq",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -122676,7 +126574,8 @@
                               "printedName": "String",
                               "usr": "s:SS"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         },
                         {
                           "kind": "TypeNominal",
@@ -122685,78 +126584,31 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:s13AnyCollectionV"
                 }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
+              ],
               "declKind": "Accessor",
               "usr": "s:s6MirrorV8childrens13AnyCollectionVySSSg5label_yp5valuetGvg",
-              "location": "",
               "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Children",
-                  "printedName": "Mirror.Children",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "AnyCollection",
-                      "printedName": "AnyCollection<(label: Optional<String>, value: Any)>",
-                      "usr": "s:s13AnyCollectionV",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Tuple",
-                          "printedName": "(label: Optional<String>, value: Any)",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Optional",
-                              "printedName": "Optional<String>",
-                              "usr": "s:Sq",
-                              "children": [
-                                {
-                                  "kind": "TypeNominal",
-                                  "name": "String",
-                                  "printedName": "String",
-                                  "usr": "s:SS"
-                                }
-                              ]
-                            },
-                            {
-                              "kind": "TypeNominal",
-                              "name": "ProtocolComposition",
-                              "printedName": "Any"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6MirrorV8childrens13AnyCollectionVySSSg5label_yp5valuetGvp",
+          "moduleName": "Swift",
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Var",
           "name": "displayStyle",
           "printedName": "displayStyle",
-          "declKind": "Var",
-          "usr": "s:s6MirrorV12displayStyleAB07DisplayC0OSgvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Mirror.DisplayStyle?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Mirror.DisplayStyle>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122764,22 +126616,18 @@
                   "printedName": "Mirror.DisplayStyle",
                   "usr": "s:s6MirrorV12DisplayStyleO"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6MirrorV12displayStyleAB07DisplayC0OSgvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Mirror.DisplayStyle?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<Mirror.DisplayStyle>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -122787,26 +126635,31 @@
                       "printedName": "Mirror.DisplayStyle",
                       "usr": "s:s6MirrorV12DisplayStyleO"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6MirrorV12displayStyleAB07DisplayC0OSgvg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6MirrorV12displayStyleAB07DisplayC0OSgvp",
+          "moduleName": "Swift",
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Var",
           "name": "superclassMirror",
           "printedName": "superclassMirror",
-          "declKind": "Var",
-          "usr": "s:s6MirrorV010superclassA0ABSgvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Mirror?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Mirror>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122814,22 +126667,18 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6MirrorV010superclassA0ABSgvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Mirror?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<Mirror>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -122837,20 +126686,23 @@
                       "printedName": "Mirror",
                       "usr": "s:s6MirrorV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6MirrorV010superclassA0ABSgvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6MirrorV010superclassA0ABSgvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(internalReflecting:subjectType:customAncestor:)",
-          "declKind": "Constructor",
-          "usr": "s:s6MirrorV18internalReflecting11subjectType14customAncestorAByp_ypXpSgABSgtcfc",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -122866,9 +126718,7 @@
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Any.Type?",
-              "hasDefaultArg": true,
-              "usr": "s:Sq",
+              "printedName": "Optional<Any.Type>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122882,14 +126732,14 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "hasDefaultArg": true,
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Mirror?",
-              "hasDefaultArg": true,
-              "usr": "s:Sq",
+              "printedName": "Optional<Mirror>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122897,31 +126747,33 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "hasDefaultArg": true,
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6MirrorV18internalReflecting11subjectType14customAncestorAByp_ypXpSgABSgtcfc",
+          "moduleName": "Swift",
+          "isInternal": true
         },
         {
           "kind": "Function",
           "name": "descendant",
           "printedName": "descendant(_:_:)",
-          "declKind": "Func",
-          "usr": "s:s6MirrorV10descendantyypSgs0A4Path_p_sAE_pdtF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Any?",
-              "usr": "s:Sq",
+              "printedName": "Optional<Any>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ProtocolComposition",
                   "printedName": "Any"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -122932,8 +126784,7 @@
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[MirrorPath]",
-              "usr": "s:Sa",
+              "printedName": "Array<MirrorPath>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122941,18 +126792,18 @@
                   "printedName": "MirrorPath",
                   "usr": "s:s10MirrorPathP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s6MirrorV10descendantyypSgs0A4Path_p_sAE_pdtF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:s6MirrorV11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -122964,10 +126815,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6MirrorV11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122975,18 +126822,20 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6MirrorV11descriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6MirrorV11descriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s6MirrorV06customA0ABvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -122998,10 +126847,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6MirrorV06customA0ABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -123009,29 +126854,34 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6MirrorV06customA0ABvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6MirrorV06customA0ABvp",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s6MirrorV",
+      "moduleName": "Swift",
+      "conformingProtocols": [
+        "CustomStringConvertible",
+        "CustomReflectable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "CustomReflectable",
       "printedName": "CustomReflectable",
-      "declKind": "Protocol",
-      "usr": "s:s17CustomReflectableP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s17CustomReflectableP12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -123043,11 +126893,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17CustomReflectableP12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CustomReflectable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -123055,11 +126900,22 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17CustomReflectableP12customMirrors0D0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : CustomReflectable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17CustomReflectableP12customMirrors0D0Vvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s17CustomReflectableP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
@@ -123067,9 +126923,8 @@
       "printedName": "CustomLeafReflectable",
       "declKind": "Protocol",
       "usr": "s:s21CustomLeafReflectableP",
-      "location": "",
       "moduleName": "Swift",
-      "genericSig": "<Self : CustomReflectable>",
+      "genericSig": "<τ_0_0 : CustomReflectable>",
       "conformingProtocols": [
         "CustomReflectable"
       ]
@@ -123080,362 +126935,17 @@
       "printedName": "MirrorPath",
       "declKind": "Protocol",
       "usr": "s:s10MirrorPathP",
-      "location": "",
       "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
-      "name": "DictionaryLiteral",
-      "printedName": "DictionaryLiteral",
-      "declKind": "Struct",
-      "usr": "s:s17DictionaryLiteralV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Key, Value>",
-      "conformingProtocols": [
-        "ExpressibleByDictionaryLiteral",
-        "RandomAccessCollection",
-        "BidirectionalCollection",
-        "Collection",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(dictionaryLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s17DictionaryLiteralV010dictionaryB0AByxq_Gx_q_td_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DictionaryLiteral",
-              "printedName": "DictionaryLiteral<Key, Value>",
-              "usr": "s:s17DictionaryLiteralV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Key"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "[(Key, Value)]",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(Key, Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Key",
-          "printedName": "Key",
-          "declKind": "TypeAlias",
-          "usr": "s:s17DictionaryLiteralV3Keya",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Key"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Value",
-          "printedName": "Value",
-          "declKind": "TypeAlias",
-          "usr": "s:s17DictionaryLiteralV5Valuea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Value"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s17DictionaryLiteralV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Int>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s17DictionaryLiteralV10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17DictionaryLiteralV10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s17DictionaryLiteralV8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17DictionaryLiteralV8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s17DictionaryLiteralV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(key: Key, value: Value)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Key"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s17DictionaryLiteralV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s17DictionaryLiteralV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<DictionaryLiteral<Key, Value>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DictionaryLiteral",
-                  "printedName": "DictionaryLiteral<Key, Value>",
-                  "usr": "s:s17DictionaryLiteralV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s17DictionaryLiteralV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "IndexingIterator",
-              "printedName": "IndexingIterator<DictionaryLiteral<Key, Value>>",
-              "usr": "s:s16IndexingIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DictionaryLiteral",
-                  "printedName": "DictionaryLiteral<Key, Value>",
-                  "usr": "s:s17DictionaryLiteralV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
       "name": "CustomPlaygroundDisplayConvertible",
       "printedName": "CustomPlaygroundDisplayConvertible",
-      "declKind": "Protocol",
-      "usr": "s:s34CustomPlaygroundDisplayConvertibleP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "playgroundDescription",
           "printedName": "playgroundDescription",
-          "declKind": "Var",
-          "usr": "s:s34CustomPlaygroundDisplayConvertibleP21playgroundDescriptionypvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -123446,47 +126956,38 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s34CustomPlaygroundDisplayConvertibleP21playgroundDescriptionypvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CustomPlaygroundDisplayConvertible>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ProtocolComposition",
                   "printedName": "Any"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s34CustomPlaygroundDisplayConvertibleP21playgroundDescriptionypvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0 where τ_0_0 : CustomPlaygroundDisplayConvertible>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s34CustomPlaygroundDisplayConvertibleP21playgroundDescriptionypvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s34CustomPlaygroundDisplayConvertibleP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "CommandLine",
       "printedName": "CommandLine",
-      "declKind": "Enum",
-      "usr": "s:s11CommandLineO",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Frozen"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "argc",
           "printedName": "argc",
-          "declKind": "Var",
-          "usr": "s:s11CommandLineO4argcs5Int32VvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -123498,11 +126999,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11CommandLineO4argcs5Int32VvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -123510,40 +127006,37 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11CommandLineO4argcs5Int32VvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s11CommandLineO4argcs5Int32VvpZ",
+          "moduleName": "Swift",
+          "static": true
         },
         {
           "kind": "Var",
           "name": "unsafeArgv",
           "printedName": "unsafeArgv",
-          "declKind": "Var",
-          "usr": "s:s11CommandLineO10unsafeArgvSpySpys4Int8VGSgGvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
-              "printedName": "UnsafeMutablePointer<UnsafeMutablePointer<Int8>?>",
-              "usr": "s:Sp",
+              "printedName": "UnsafeMutablePointer<Optional<UnsafeMutablePointer<Int8>>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "UnsafeMutablePointer<Int8>?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<UnsafeMutablePointer<Int8>>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafeMutablePointer",
                       "printedName": "UnsafeMutablePointer<Int8>",
-                      "usr": "s:Sp",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -123551,39 +127044,34 @@
                           "printedName": "Int8",
                           "usr": "s:s4Int8V"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sp"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11CommandLineO10unsafeArgvSpySpys4Int8VGSgGvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafeMutablePointer",
-                  "printedName": "UnsafeMutablePointer<UnsafeMutablePointer<Int8>?>",
-                  "usr": "s:Sp",
+                  "printedName": "UnsafeMutablePointer<Optional<UnsafeMutablePointer<Int8>>>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
-                      "printedName": "UnsafeMutablePointer<Int8>?",
-                      "usr": "s:Sq",
+                      "printedName": "Optional<UnsafeMutablePointer<Int8>>",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "UnsafeMutablePointer",
                           "printedName": "UnsafeMutablePointer<Int8>",
-                          "usr": "s:Sp",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -123591,34 +127079,36 @@
                               "printedName": "Int8",
                               "usr": "s:s4Int8V"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sp"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11CommandLineO10unsafeArgvSpySpys4Int8VGSgGvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s11CommandLineO10unsafeArgvSpySpys4Int8VGSgGvpZ",
+          "moduleName": "Swift",
+          "static": true
         },
         {
           "kind": "Var",
           "name": "arguments",
           "printedName": "arguments",
-          "declKind": "Var",
-          "usr": "s:s11CommandLineO9argumentsSaySSGvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "HasInitialValue"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[String]",
-              "usr": "s:Sa",
+              "printedName": "Array<String>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -123626,23 +127116,18 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11CommandLineO9argumentsSaySSGvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[String]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<String>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -123650,19 +127135,20 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11CommandLineO9argumentsSaySSGvgZ",
+              "moduleName": "Swift",
+              "static": true,
+              "implicit": true
             },
             {
               "kind": "Setter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11CommandLineO9argumentsSaySSGvsZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -123672,8 +127158,7 @@
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
-                  "printedName": "[String]",
-                  "usr": "s:Sa",
+                  "printedName": "Array<String>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -123681,220 +127166,2460 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11CommandLineO9argumentsSaySSGvsZ",
+              "moduleName": "Swift",
+              "static": true,
+              "implicit": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s11CommandLineO9argumentsSaySSGvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "HasInitialValue"
+          ],
+          "hasStorage": true
+        }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s11CommandLineO",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Frozen"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "==",
+      "printedName": "==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2eeoiySbyt_yttF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbyt_yttF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<",
+      "printedName": "<(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1loiySbyt_yttF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<=",
+      "printedName": "<=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2leoiySbyt_yttF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">",
+      "printedName": ">(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1goiySbyt_yttF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">=",
+      "printedName": ">=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2geoiySbyt_yttF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "==",
+      "printedName": "==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
             }
           ]
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2eeoiySbx_q_t_x_q_ttSQRzSQR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Equatable, τ_0_1 : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbx_q_t_x_q_ttSQRzSQR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Equatable, τ_0_1 : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<",
+      "printedName": "<(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1loiySbx_q_t_x_q_ttSLRzSLR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Comparable, τ_0_1 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<=",
+      "printedName": "<=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2leoiySbx_q_t_x_q_ttSLRzSLR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Comparable, τ_0_1 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">",
+      "printedName": ">(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1goiySbx_q_t_x_q_ttSLRzSLR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Comparable, τ_0_1 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">=",
+      "printedName": ">=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2geoiySbx_q_t_x_q_ttSLRzSLR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Comparable, τ_0_1 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "==",
+      "printedName": "==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2eeoiySbx_q_q0_t_x_q_q0_ttSQRzSQR_SQR0_r1_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2 where τ_0_0 : Equatable, τ_0_1 : Equatable, τ_0_2 : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbx_q_q0_t_x_q_q0_ttSQRzSQR_SQR0_r1_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2 where τ_0_0 : Equatable, τ_0_1 : Equatable, τ_0_2 : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<",
+      "printedName": "<(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1loiySbx_q_q0_t_x_q_q0_ttSLRzSLR_SLR0_r1_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2 where τ_0_0 : Comparable, τ_0_1 : Comparable, τ_0_2 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<=",
+      "printedName": "<=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2leoiySbx_q_q0_t_x_q_q0_ttSLRzSLR_SLR0_r1_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2 where τ_0_0 : Comparable, τ_0_1 : Comparable, τ_0_2 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">",
+      "printedName": ">(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1goiySbx_q_q0_t_x_q_q0_ttSLRzSLR_SLR0_r1_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2 where τ_0_0 : Comparable, τ_0_1 : Comparable, τ_0_2 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">=",
+      "printedName": ">=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2geoiySbx_q_q0_t_x_q_q0_ttSLRzSLR_SLR0_r1_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2 where τ_0_0 : Comparable, τ_0_1 : Comparable, τ_0_2 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "==",
+      "printedName": "==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2eeoiySbx_q_q0_q1_t_x_q_q0_q1_ttSQRzSQR_SQR0_SQR1_r2_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3 where τ_0_0 : Equatable, τ_0_1 : Equatable, τ_0_2 : Equatable, τ_0_3 : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbx_q_q0_q1_t_x_q_q0_q1_ttSQRzSQR_SQR0_SQR1_r2_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3 where τ_0_0 : Equatable, τ_0_1 : Equatable, τ_0_2 : Equatable, τ_0_3 : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<",
+      "printedName": "<(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1loiySbx_q_q0_q1_t_x_q_q0_q1_ttSLRzSLR_SLR0_SLR1_r2_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3 where τ_0_0 : Comparable, τ_0_1 : Comparable, τ_0_2 : Comparable, τ_0_3 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<=",
+      "printedName": "<=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2leoiySbx_q_q0_q1_t_x_q_q0_q1_ttSLRzSLR_SLR0_SLR1_r2_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3 where τ_0_0 : Comparable, τ_0_1 : Comparable, τ_0_2 : Comparable, τ_0_3 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">",
+      "printedName": ">(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1goiySbx_q_q0_q1_t_x_q_q0_q1_ttSLRzSLR_SLR0_SLR1_r2_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3 where τ_0_0 : Comparable, τ_0_1 : Comparable, τ_0_2 : Comparable, τ_0_3 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">=",
+      "printedName": ">=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2geoiySbx_q_q0_q1_t_x_q_q0_q1_ttSLRzSLR_SLR0_SLR1_r2_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3 where τ_0_0 : Comparable, τ_0_1 : Comparable, τ_0_2 : Comparable, τ_0_3 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "==",
+      "printedName": "==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2eeoiySbx_q_q0_q1_q2_t_x_q_q0_q1_q2_ttSQRzSQR_SQR0_SQR1_SQR2_r3_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4 where τ_0_0 : Equatable, τ_0_1 : Equatable, τ_0_2 : Equatable, τ_0_3 : Equatable, τ_0_4 : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbx_q_q0_q1_q2_t_x_q_q0_q1_q2_ttSQRzSQR_SQR0_SQR1_SQR2_r3_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4 where τ_0_0 : Equatable, τ_0_1 : Equatable, τ_0_2 : Equatable, τ_0_3 : Equatable, τ_0_4 : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<",
+      "printedName": "<(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1loiySbx_q_q0_q1_q2_t_x_q_q0_q1_q2_ttSLRzSLR_SLR0_SLR1_SLR2_r3_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4 where τ_0_0 : Comparable, τ_0_1 : Comparable, τ_0_2 : Comparable, τ_0_3 : Comparable, τ_0_4 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<=",
+      "printedName": "<=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2leoiySbx_q_q0_q1_q2_t_x_q_q0_q1_q2_ttSLRzSLR_SLR0_SLR1_SLR2_r3_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4 where τ_0_0 : Comparable, τ_0_1 : Comparable, τ_0_2 : Comparable, τ_0_3 : Comparable, τ_0_4 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">",
+      "printedName": ">(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1goiySbx_q_q0_q1_q2_t_x_q_q0_q1_q2_ttSLRzSLR_SLR0_SLR1_SLR2_r3_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4 where τ_0_0 : Comparable, τ_0_1 : Comparable, τ_0_2 : Comparable, τ_0_3 : Comparable, τ_0_4 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">=",
+      "printedName": ">=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2geoiySbx_q_q0_q1_q2_t_x_q_q0_q1_q2_ttSLRzSLR_SLR0_SLR1_SLR2_r3_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4 where τ_0_0 : Comparable, τ_0_1 : Comparable, τ_0_2 : Comparable, τ_0_3 : Comparable, τ_0_4 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "==",
+      "printedName": "==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_5"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_5"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2eeoiySbx_q_q0_q1_q2_q3_t_x_q_q0_q1_q2_q3_ttSQRzSQR_SQR0_SQR1_SQR2_SQR3_r4_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5 where τ_0_0 : Equatable, τ_0_1 : Equatable, τ_0_2 : Equatable, τ_0_3 : Equatable, τ_0_4 : Equatable, τ_0_5 : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_5"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_5"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbx_q_q0_q1_q2_q3_t_x_q_q0_q1_q2_q3_ttSQRzSQR_SQR0_SQR1_SQR2_SQR3_r4_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5 where τ_0_0 : Equatable, τ_0_1 : Equatable, τ_0_2 : Equatable, τ_0_3 : Equatable, τ_0_4 : Equatable, τ_0_5 : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<",
+      "printedName": "<(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_5"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_5"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1loiySbx_q_q0_q1_q2_q3_t_x_q_q0_q1_q2_q3_ttSLRzSLR_SLR0_SLR1_SLR2_SLR3_r4_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5 where τ_0_0 : Comparable, τ_0_1 : Comparable, τ_0_2 : Comparable, τ_0_3 : Comparable, τ_0_4 : Comparable, τ_0_5 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<=",
+      "printedName": "<=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_5"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_5"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2leoiySbx_q_q0_q1_q2_q3_t_x_q_q0_q1_q2_q3_ttSLRzSLR_SLR0_SLR1_SLR2_SLR3_r4_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5 where τ_0_0 : Comparable, τ_0_1 : Comparable, τ_0_2 : Comparable, τ_0_3 : Comparable, τ_0_4 : Comparable, τ_0_5 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">",
+      "printedName": ">(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_5"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_5"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1goiySbx_q_q0_q1_q2_q3_t_x_q_q0_q1_q2_q3_ttSLRzSLR_SLR0_SLR1_SLR2_SLR3_r4_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5 where τ_0_0 : Comparable, τ_0_1 : Comparable, τ_0_2 : Comparable, τ_0_3 : Comparable, τ_0_4 : Comparable, τ_0_5 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">=",
+      "printedName": ">=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_5"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_2"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_3"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_4"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_5"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2geoiySbx_q_q0_q1_q2_q3_t_x_q_q0_q1_q2_q3_ttSLRzSLR_SLR0_SLR1_SLR2_SLR3_r4_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1, τ_0_2, τ_0_3, τ_0_4, τ_0_5 where τ_0_0 : Comparable, τ_0_1 : Comparable, τ_0_2 : Comparable, τ_0_3 : Comparable, τ_0_4 : Comparable, τ_0_5 : Comparable>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "sequence",
       "printedName": "sequence(first:next:)",
-      "declKind": "Func",
-      "usr": "s:s8sequence5first4nexts14UnfoldSequenceVyxxSg_SbtGx_AFxctlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "declAttributes": [
-        "Inlinable"
-      ],
-      "children": [
-        {
-          "kind": "TypeNameAlias",
-          "name": "UnfoldFirstSequence",
-          "printedName": "UnfoldFirstSequence<T>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnfoldSequence",
-              "printedName": "UnfoldSequence<τ_0_0, (Optional<τ_0_0>, Bool)>",
-              "usr": "s:s14UnfoldSequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(Optional<τ_0_0>, Bool)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Optional",
-                      "printedName": "Optional<τ_0_0>",
-                      "usr": "s:Sq",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_0"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Bool",
-                      "printedName": "Bool",
-                      "usr": "s:Sb"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        },
-        {
-          "kind": "TypeFunc",
-          "name": "Function",
-          "printedName": "(T) -> T?",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "T?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Paren",
-              "printedName": "(T)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "Function",
-      "name": "sequence",
-      "printedName": "sequence(state:next:)",
-      "declKind": "Func",
-      "usr": "s:s8sequence5state4nexts14UnfoldSequenceVyxq_Gq__xSgq_zctr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, State>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "UnfoldSequence",
-          "printedName": "UnfoldSequence<T, State>",
-          "usr": "s:s14UnfoldSequenceV",
+          "printedName": "UnfoldSequence<τ_0_0, (Optional<τ_0_0>, Bool)>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "T"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "State"
-            }
-          ]
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "State"
-        },
-        {
-          "kind": "TypeFunc",
-          "name": "Function",
-          "printedName": "(inout State) -> T?",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "T?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Paren",
-              "printedName": "(inout State)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "InOut",
-                  "printedName": "inout State"
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "UnfoldFirstSequence",
-      "printedName": "UnfoldFirstSequence",
-      "declKind": "TypeAlias",
-      "usr": "s:s19UnfoldFirstSequencea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "UnfoldSequence",
-          "printedName": "UnfoldSequence<T, (T?, Bool)>",
-          "usr": "s:s14UnfoldSequenceV",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "Tuple",
-              "printedName": "(T?, Bool)",
+              "printedName": "(Optional<τ_0_0>, Bool)",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "T?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<τ_0_0>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
-                      "printedName": "T"
+                      "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -123904,128 +129629,324 @@
                 }
               ]
             }
+          ],
+          "usr": "s:s14UnfoldSequenceV"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_0"
+        },
+        {
+          "kind": "TypeFunc",
+          "name": "Function",
+          "printedName": "(τ_0_0) -> Optional<τ_0_0>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            }
           ]
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s8sequence5first4nexts14UnfoldSequenceVyxxSg_SbtGx_AFxctlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "sequence",
+      "printedName": "sequence(state:next:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "UnfoldSequence",
+          "printedName": "UnfoldSequence<τ_0_0, τ_0_1>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            }
+          ],
+          "usr": "s:s14UnfoldSequenceV"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "τ_0_1"
+        },
+        {
+          "kind": "TypeFunc",
+          "name": "Function",
+          "printedName": "(inout τ_0_1) -> Optional<τ_0_0>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "InOut",
+              "printedName": "inout τ_0_1"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s8sequence5state4nexts14UnfoldSequenceVyxq_Gq__xSgq_zctr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnfoldSequence",
       "printedName": "UnfoldSequence",
-      "declKind": "Struct",
-      "usr": "s:s14UnfoldSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element, State>",
-      "conformingProtocols": [
-        "Sequence",
-        "IteratorProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s14UnfoldSequenceV4nextxSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, State>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
-              "printedName": "Element?",
-              "usr": "s:Sq",
+              "printedName": "Optional<τ_0_0>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_0"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s14UnfoldSequenceV4nextxSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0, τ_0_1>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s14UnfoldSequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, State>",
+          "kind": "Var",
+          "name": "_state",
+          "printedName": "_state",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s14UnfoldSequenceV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, State>",
-          "children": [
+              "printedName": "τ_0_1"
+            },
             {
-              "kind": "TypeNominal",
-              "name": "UnfoldSequence",
-              "printedName": "UnfoldSequence<Element, State>",
-              "usr": "s:s14UnfoldSequenceV",
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14UnfoldSequenceV6_stateq_vg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14UnfoldSequenceV6_stateq_vp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_next",
+          "printedName": "_next",
+          "children": [
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(inout τ_0_1) -> Optional<τ_0_0>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Optional<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "State"
+                  "name": "InOut",
+                  "printedName": "inout τ_0_1"
                 }
               ]
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeFunc",
+                  "name": "Function",
+                  "printedName": "(inout τ_0_1) -> Optional<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Optional<τ_0_0>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "InOut",
+                      "printedName": "inout τ_0_1"
+                    }
+                  ]
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14UnfoldSequenceV5_nextyxSgq_zcvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s14UnfoldSequenceV5_nextyxSgq_zcvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
         },
         {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s14UnfoldSequenceV03SubB0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, State>",
+          "kind": "Var",
+          "name": "_done",
+          "printedName": "_done",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "AnySequence",
-              "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14UnfoldSequenceV5_doneSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s14UnfoldSequenceV5_doneSbvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "HasInitialValue",
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 2,
+          "hasStorage": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s14UnfoldSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "IteratorProtocol"
       ]
     },
     {
@@ -124034,32 +129955,22 @@
       "printedName": "CVarArg",
       "declKind": "Protocol",
       "usr": "s:s7CVarArgP",
-      "location": "",
       "moduleName": "Swift"
     },
     {
       "kind": "Function",
       "name": "withVaList",
       "printedName": "withVaList(_:_:)",
-      "declKind": "Func",
-      "usr": "s:s10withVaListyxSays7CVarArg_pG_xs03CVaC7PointerVXEtlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<R>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "R"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "Array",
-          "printedName": "[CVarArg]",
-          "usr": "s:Sa",
+          "printedName": "Array<CVarArg>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -124067,50 +129978,43 @@
               "printedName": "CVarArg",
               "usr": "s:s7CVarArgP"
             }
-          ]
+          ],
+          "usr": "s:Sa"
         },
         {
           "kind": "TypeFunc",
           "name": "Function",
-          "printedName": "(CVaListPointer) -> R",
-          "typeAttributes": [
-            "noescape"
-          ],
+          "printedName": "(CVaListPointer) -> τ_0_0",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "R"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
-              "name": "Paren",
-              "printedName": "(CVaListPointer)",
-              "usr": "s:s14CVaListPointerV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "CVaListPointer",
-                  "printedName": "CVaListPointer",
-                  "usr": "s:s14CVaListPointerV"
-                }
-              ]
+              "name": "CVaListPointer",
+              "printedName": "CVaListPointer",
+              "usr": "s:s14CVaListPointerV"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s10withVaListyxSays7CVarArg_pG_xs03CVaC7PointerVXEtlF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "getVaList",
       "printedName": "getVaList(_:)",
-      "declKind": "Func",
-      "usr": "s:s9getVaListys03CVaC7PointerVSays7CVarArg_pGF",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -124121,8 +130025,7 @@
         {
           "kind": "TypeNominal",
           "name": "Array",
-          "printedName": "[CVarArg]",
-          "usr": "s:Sa",
+          "printedName": "Array<CVarArg>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -124130,380 +130033,426 @@
               "printedName": "CVarArg",
               "usr": "s:s7CVarArgP"
             }
-          ]
+          ],
+          "usr": "s:Sa"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s9getVaListys03CVaC7PointerVSays7CVarArg_pGF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "zip",
       "printedName": "zip(_:_:)",
-      "declKind": "Func",
-      "usr": "s:s3zipys12Zip2SequenceVyxq_Gx_q_tSTRzSTR_r0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Zip2Sequence",
-          "printedName": "Zip2Sequence<Sequence1, Sequence2>",
-          "usr": "s:s12Zip2SequenceV",
+          "printedName": "Zip2Sequence<τ_0_0, τ_0_1>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Sequence1"
+              "printedName": "τ_0_0"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
-              "printedName": "Sequence2"
+              "printedName": "τ_0_1"
             }
-          ]
+          ],
+          "usr": "s:s12Zip2SequenceV"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "Sequence1"
+          "printedName": "τ_0_0"
         },
         {
           "kind": "TypeNominal",
           "name": "GenericTypeParam",
-          "printedName": "Sequence2"
+          "printedName": "τ_0_1"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s3zipys12Zip2SequenceVyxq_Gx_q_tSTRzSTR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence, τ_0_1 : Sequence>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Zip2Sequence",
       "printedName": "Zip2Sequence",
-      "declKind": "Struct",
-      "usr": "s:s12Zip2SequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-      "conformingProtocols": [
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
+          "kind": "Var",
+          "name": "_sequence1",
+          "printedName": "_sequence1",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_0"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12Zip2SequenceV10_sequence1xvg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence, τ_0_1 : Sequence>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12Zip2SequenceV10_sequence1xvp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
+          "kind": "Var",
+          "name": "_sequence2",
+          "printedName": "_sequence2",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "τ_0_1"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12Zip2SequenceV10_sequence2q_vg",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence, τ_0_1 : Sequence>",
+              "implicit": true,
+              "isInternal": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12Zip2SequenceV10_sequence2q_vp",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "UsableFromInline"
+          ],
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s12Zip2SequenceV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-          "conformingProtocols": [
-            "IteratorProtocol"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
+              "kind": "Var",
+              "name": "_baseStream1",
+              "printedName": "_baseStream1",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Iterator"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Iterator"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s12Zip2SequenceV8IteratorV12_baseStream1ACQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence, τ_0_1 : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s12Zip2SequenceV8IteratorV12_baseStream1ACQzvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 0,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_baseStream2",
+              "printedName": "_baseStream2",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_1.Iterator"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_1.Iterator"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s12Zip2SequenceV8IteratorV12_baseStream2ACQy_vg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence, τ_0_1 : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s12Zip2SequenceV8IteratorV12_baseStream2ACQy_vp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 1,
+              "hasStorage": true
+            },
+            {
+              "kind": "Var",
+              "name": "_reachedEnd",
+              "printedName": "_reachedEnd",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s12Zip2SequenceV8IteratorV11_reachedEndSbvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence, τ_0_1 : Sequence>",
+                  "implicit": true,
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Transparent"
+                  ]
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:s12Zip2SequenceV8IteratorV11_reachedEndSbvp",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "HasInitialValue",
+                "UsableFromInline"
+              ],
+              "fixedbinaryorder": 2,
+              "hasStorage": true
+            },
+            {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:_:)",
-              "declKind": "Constructor",
-              "usr": "s:s12Zip2SequenceV8IteratorVyADyxq__GACQz_ACQy_tcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Iterator",
-                  "printedName": "Zip2Sequence<Sequence1, Sequence2>.Iterator",
+                  "printedName": "Zip2Sequence<τ_0_0, τ_0_1>.Iterator",
                   "usr": "s:s12Zip2SequenceV8IteratorV"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Sequence1.Iterator"
+                  "printedName": "τ_0_0.Iterator"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Sequence2.Iterator"
+                  "printedName": "τ_0_1.Iterator"
                 }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s12Zip2SequenceV8IteratorV7Elementa",
-              "location": "",
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s12Zip2SequenceV8IteratorVyADyxq__GACQz_ACQy_tcfc",
               "moduleName": "Swift",
-              "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(Sequence1.Element, Sequence2.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Sequence1.Element"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Sequence2.Element"
-                    }
-                  ]
-                }
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence, τ_0_1 : Sequence>",
+              "isInternal": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s12Zip2SequenceV8IteratorV4next7ElementQz_AFQy_tSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
-                  "printedName": "Zip2Sequence<Sequence1, Sequence2>.Iterator.Element?",
-                  "usr": "s:Sq",
+                  "printedName": "Optional<(τ_0_0.Element, τ_0_1.Element)>",
                   "children": [
                     {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "Zip2Sequence<Sequence1, Sequence2>.Iterator.Element",
+                      "kind": "TypeNominal",
+                      "name": "Tuple",
+                      "printedName": "(τ_0_0.Element, τ_0_1.Element)",
                       "children": [
                         {
                           "kind": "TypeNominal",
-                          "name": "Tuple",
-                          "printedName": "(τ_0_0.Element, τ_0_1.Element)",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "DependentMember",
-                              "printedName": "τ_0_0.Element"
-                            },
-                            {
-                              "kind": "TypeNominal",
-                              "name": "DependentMember",
-                              "printedName": "τ_0_1.Element"
-                            }
-                          ]
+                          "name": "DependentMember",
+                          "printedName": "τ_0_0.Element"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "DependentMember",
+                          "printedName": "τ_0_1.Element"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s12Zip2SequenceV8IteratorV4next7ElementQz_AFQy_tSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence, τ_0_1 : Sequence>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stream1",
-          "printedName": "Stream1",
-          "declKind": "TypeAlias",
-          "usr": "s:s12Zip2SequenceV7Stream1a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Sequence1.Iterator"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Stream2",
-          "printedName": "Stream2",
-          "declKind": "TypeAlias",
-          "usr": "s:s12Zip2SequenceV7Stream2a",
-          "location": "",
+          "declKind": "Struct",
+          "usr": "s:s12Zip2SequenceV8IteratorV",
           "moduleName": "Swift",
-          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-          "deprecated": true,
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence, τ_0_1 : Sequence>",
           "declAttributes": [
-            "Available"
+            "FixedLayout"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Sequence2.Iterator"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s12Zip2SequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(Sequence1.Element, Sequence2.Element)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Sequence1.Element"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Sequence2.Element"
-                }
-              ]
-            }
+          "conformingProtocols": [
+            "IteratorProtocol"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s12Zip2SequenceV12makeIteratorAB0D0Vyxq__GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Iterator",
-              "printedName": "Zip2Sequence<Sequence1, Sequence2>.Iterator",
+              "printedName": "Zip2Sequence<τ_0_0, τ_0_1>.Iterator",
               "usr": "s:s12Zip2SequenceV8IteratorV"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s12Zip2SequenceV03SubB0a",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s12Zip2SequenceV12makeIteratorAB0D0Vyxq__GyF",
           "moduleName": "Swift",
-          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnySequence",
-              "printedName": "AnySequence<(Sequence1.Element, Sequence2.Element)>",
-              "usr": "s:s11AnySequenceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(Sequence1.Element, Sequence2.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Sequence1.Element"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Sequence2.Element"
-                    }
-                  ]
-                }
-              ]
-            }
+          "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence, τ_0_1 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s12Zip2SequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Sequence, τ_0_1 : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "ArrayProtocol",
       "printedName": "ArrayProtocol",
-      "declKind": "Protocol",
-      "usr": "s:s13ArrayProtocolP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : ExpressibleByArrayLiteral, Self : RangeReplaceableCollection, Self._Buffer : _ArrayBufferProtocol>",
-      "conformingProtocols": [
-        "RangeReplaceableCollection",
-        "ExpressibleByArrayLiteral",
-        "Collection",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "UsableFromInline"
-      ],
       "children": [
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:s13ArrayProtocolPsE6filterySay7ElementQzGSbAEKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ArrayProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
-              "printedName": "[Self.Element]",
-              "usr": "s:Sa",
+              "printedName": "Array<τ_0_0.Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
-                  "printedName": "Self.Element"
+                  "printedName": "τ_0_0.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "printedName": "(τ_0_0.Element) throws -> Bool",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -124513,20 +130462,190 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13ArrayProtocolPsE6filterySay7ElementQzGSbAEKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<τ_0_0 where τ_0_0 : ArrayProtocol>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s13ArrayProtocolP",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 : ExpressibleByArrayLiteral, τ_0_0 : RangeReplaceableCollection, τ_0_0._Buffer : _ArrayBufferProtocol>",
+      "isInternal": true,
+      "declAttributes": [
+        "UsableFromInline"
+      ],
+      "conformingProtocols": [
+        "RangeReplaceableCollection",
+        "ExpressibleByArrayLiteral",
+        "Collection",
+        "Sequence"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Word",
+      "printedName": "Word",
+      "declKind": "Struct",
+      "usr": "s:s13_UnsafeBitsetV4WordV",
+      "moduleName": "Swift",
+      "isInternal": true,
+      "declAttributes": [
+        "UsableFromInline",
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "IteratorProtocol"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Index",
+      "printedName": "Index",
+      "declKind": "Struct",
+      "usr": "s:s16_CocoaDictionaryV5IndexV",
+      "moduleName": "Swift",
+      "isInternal": true,
+      "declAttributes": [
+        "UsableFromInline",
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Comparable"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Iterator",
+      "printedName": "Iterator",
+      "declKind": "Class",
+      "usr": "s:s16_CocoaDictionaryV8IteratorC",
+      "moduleName": "Swift",
+      "isInternal": true,
+      "declAttributes": [
+        "Final",
+        "UsableFromInline"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Bucket",
+      "printedName": "Bucket",
+      "declKind": "Struct",
+      "usr": "s:s10_HashTableV6BucketV",
+      "moduleName": "Swift",
+      "isInternal": true,
+      "declAttributes": [
+        "UsableFromInline",
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Comparable"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Index",
+      "printedName": "Index",
+      "declKind": "Struct",
+      "usr": "s:s10_HashTableV5IndexV",
+      "moduleName": "Swift",
+      "isInternal": true,
+      "declAttributes": [
+        "FixedLayout",
+        "UsableFromInline"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Comparable"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Iterator",
+      "printedName": "Iterator",
+      "declKind": "Struct",
+      "usr": "s:s17_NativeDictionaryV8IteratorV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0, τ_0_1 where τ_0_0 : Hashable>",
+      "isInternal": true,
+      "declAttributes": [
+        "FixedLayout",
+        "UsableFromInline"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Iterator",
+      "printedName": "Iterator",
+      "declKind": "Struct",
+      "usr": "s:s10_NativeSetV8IteratorV",
+      "moduleName": "Swift",
+      "genericSig": "<τ_0_0 where τ_0_0 : Hashable>",
+      "isInternal": true,
+      "declAttributes": [
+        "FixedLayout",
+        "UsableFromInline"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Index",
+      "printedName": "Index",
+      "declKind": "Struct",
+      "usr": "s:s9_CocoaSetV5IndexV",
+      "moduleName": "Swift",
+      "isInternal": true,
+      "declAttributes": [
+        "UsableFromInline",
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Comparable"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Iterator",
+      "printedName": "Iterator",
+      "declKind": "Class",
+      "usr": "s:s9_CocoaSetV8IteratorC",
+      "moduleName": "Swift",
+      "isInternal": true,
+      "declAttributes": [
+        "Final",
+        "UsableFromInline"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol"
       ]
     }
   ]
diff --git a/test/api-digester/stdlib-stable.json b/test/api-digester/Inputs/stdlib-stable.json
similarity index 82%
rename from test/api-digester/stdlib-stable.json
rename to test/api-digester/Inputs/stdlib-stable.json
index 9c07404..9f70ddf 100644
--- a/test/api-digester/stdlib-stable.json
+++ b/test/api-digester/Inputs/stdlib-stable.json
@@ -7,14 +7,6 @@
       "kind": "Function",
       "name": "min",
       "printedName": "min(_:_:)",
-      "declKind": "Func",
-      "usr": "s:s3minyxx_xtSLRzlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Comparable>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -31,20 +23,19 @@
           "name": "GenericTypeParam",
           "printedName": "T"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s3minyxx_xtSLRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : Comparable>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "min",
       "printedName": "min(_:_:_:_:)",
-      "declKind": "Func",
-      "usr": "s:s3minyxx_xxxdtSLRzlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Comparable>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -70,29 +61,28 @@
           "kind": "TypeNominal",
           "name": "Array",
           "printedName": "[T]",
-          "usr": "s:Sa",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:Sa"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s3minyxx_xxxdtSLRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : Comparable>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "max",
       "printedName": "max(_:_:)",
-      "declKind": "Func",
-      "usr": "s:s3maxyxx_xtSLRzlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Comparable>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -109,20 +99,19 @@
           "name": "GenericTypeParam",
           "printedName": "T"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s3maxyxx_xtSLRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : Comparable>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "max",
       "printedName": "max(_:_:_:_:)",
-      "declKind": "Func",
-      "usr": "s:s3maxyxx_xxxdtSLRzlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Comparable>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -148,59 +137,38 @@
           "kind": "TypeNominal",
           "name": "Array",
           "printedName": "[T]",
-          "usr": "s:Sa",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:Sa"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s3maxyxx_xxxdtSLRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : Comparable>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "EnumeratedSequence",
       "printedName": "EnumeratedSequence",
-      "declKind": "Struct",
-      "usr": "s:s18EnumeratedSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Sequence>",
-      "conformingProtocols": [
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s18EnumeratedSequenceV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "conformingProtocols": [
-            "IteratorProtocol",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s18EnumeratedSequenceV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -220,27 +188,21 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s18EnumeratedSequenceV8IteratorV7Elementa",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence>"
             },
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s18EnumeratedSequenceV8IteratorV4nextSi6offset_7ElementQz7elementtSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "EnumeratedSequence<Base>.Iterator.Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -267,19 +229,23 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s18EnumeratedSequenceV8IteratorV4nextSi6offset_7ElementQz7elementtSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s18EnumeratedSequenceV8IteratorVACa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -287,23 +253,22 @@
                   "printedName": "EnumeratedSequence<Base>.Iterator",
                   "usr": "s:s18EnumeratedSequenceV8IteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s18EnumeratedSequenceV8IteratorVACa",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence>",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s18EnumeratedSequenceV8IteratorV03SubB0a",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnySequence",
                   "printedName": "AnySequence<(offset: Int, element: Base.Element)>",
-                  "usr": "s:s11AnySequenceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -323,24 +288,33 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:s11AnySequenceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s18EnumeratedSequenceV8IteratorV03SubB0a",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence>",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s18EnumeratedSequenceV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "Sequence"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s18EnumeratedSequenceV12makeIteratorAB0D0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -348,17 +322,19 @@
               "printedName": "EnumeratedSequence<Base>.Iterator",
               "usr": "s:s18EnumeratedSequenceV8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s18EnumeratedSequenceV12makeIteratorAB0D0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s18EnumeratedSequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -378,23 +354,22 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s18EnumeratedSequenceV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s18EnumeratedSequenceV03SubB0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<(offset: Int, element: Base.Element)>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -414,21 +389,1468 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s18EnumeratedSequenceV03SubB0a",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s18EnumeratedSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<Base where Base : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Array",
       "printedName": "Array",
+      "children": [
+        {
+          "kind": "TypeAlias",
+          "name": "Index",
+          "printedName": "Index",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sa5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "Indices",
+          "printedName": "Indices",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sa7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "Iterator",
+          "printedName": "Iterator",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "IndexingIterator",
+              "printedName": "IndexingIterator<Array<Element>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Array",
+                  "printedName": "Array<Element>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Element"
+                    }
+                  ],
+                  "usr": "s:Sa"
+                }
+              ],
+              "usr": "s:s16IndexingIteratorV"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sa8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sa10startIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sa10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sa8endIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sa8endIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa5index5afterS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa9formIndex5afterySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa5index6beforeS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa9formIndex6beforeySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa5index_8offsetByS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:limitedBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Int?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa5index_8offsetBy07limitedC0SiSgSi_S2itF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(from:to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa8distance4from2toS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SayxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ArraySlice",
+              "printedName": "ArraySlice<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:s10ArraySliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Says10ArraySliceVyxGSnySiGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "Element",
+          "printedName": "Element",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Element"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sa7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ArraySlice",
+              "printedName": "ArraySlice<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:s10ArraySliceV"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sa11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(arrayLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:Sa"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "[Array<Element>.Element]",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Element",
+                  "printedName": "Array<Element>.Element",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sa"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sa12arrayLiteralSayxGxd_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "ArrayLiteralElement",
+          "printedName": "ArrayLiteralElement",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Element"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sa19ArrayLiteralElementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:Sa"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:S2ayxGycfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:Sa"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "S"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SaySayxGqd__c7ElementQyd__RszSTRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(repeating:count:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:Sa"
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Element",
+              "printedName": "Array<Element>.Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sa9repeating5countSayxGx_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "count",
+          "printedName": "count",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sa5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sa5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "capacity",
+          "printedName": "capacity",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sa8capacitySivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sa8capacitySivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "reserveCapacity",
+          "printedName": "reserveCapacity(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa15reserveCapacityyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "append",
+          "printedName": "append(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Element",
+              "printedName": "Array<Element>.Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa6appendyyxnF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "append",
+          "printedName": "append(contentsOf:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "S"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa6append10contentsOfyqd__n_t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "remove",
+          "printedName": "remove(at:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Element",
+              "printedName": "Array<Element>.Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa6remove2atxSi_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "insert",
+          "printedName": "insert(_:at:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Element",
+              "printedName": "Array<Element>.Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa6insert_2atyxn_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "removeAll",
+          "printedName": "removeAll(keepingCapacity:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "hasDefaultArg": true,
+              "usr": "s:Sb"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa9removeAll15keepingCapacityySb_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Var",
+          "name": "customMirror",
+          "printedName": "customMirror",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Mirror",
+              "printedName": "Mirror",
+              "usr": "s:s6MirrorV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sa12customMirrors0B0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sa12customMirrors0B0Vvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "description",
+          "printedName": "description",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sa11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sa11descriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sa16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sa16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeBufferPointer",
+          "printedName": "withUnsafeBufferPointer(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "R"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafeBufferPointer<Array<Element>.Element>) throws -> R",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "R"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Paren",
+                  "printedName": "(UnsafeBufferPointer<Array<Element>.Element>)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafeBufferPointer",
+                      "printedName": "UnsafeBufferPointer<Array<Element>.Element>",
+                      "children": [
+                        {
+                          "kind": "TypeNameAlias",
+                          "name": "Element",
+                          "printedName": "Array<Element>.Element",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "GenericTypeParam",
+                              "printedName": "τ_0_0"
+                            }
+                          ]
+                        }
+                      ],
+                      "usr": "s:SR"
+                    }
+                  ],
+                  "usr": "s:SR"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa23withUnsafeBufferPointeryqd__qd__SRyxGKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, R>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeMutableBufferPointer",
+          "printedName": "withUnsafeMutableBufferPointer(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "R"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(inout UnsafeMutableBufferPointer<Array<Element>.Element>) throws -> R",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "R"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Paren",
+                  "printedName": "(inout UnsafeMutableBufferPointer<Array<Element>.Element>)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "InOut",
+                      "printedName": "inout UnsafeMutableBufferPointer<Array<Element>.Element>"
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa30withUnsafeMutableBufferPointeryqd__qd__SryxGzKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, R>",
+          "declAttributes": [
+            "Rethrows",
+            "Inline",
+            "Semantics"
+          ],
+          "throwing": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "replaceSubrange",
+          "printedName": "replaceSubrange(_:with:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa15replaceSubrange_4withySnySiG_qd__nt7ElementQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, C where Element == C.Element, C : Collection>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<Array<Element>.Element>",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Element",
+                  "printedName": "Array<Element>.Element",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sa"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<Array<Element>.Element>",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Element",
+                  "printedName": "Array<Element>.Element",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sa"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SasSQRzlE2eeoiySbSayxG_ABtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Equatable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "hash",
+          "printedName": "hash(into:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Hasher",
+              "printedName": "Hasher",
+              "usr": "s:s6HasherV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SasSHRzlE4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "hashValue",
+          "printedName": "hashValue",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SasSHRzlE9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>",
+              "implicit": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SasSHRzlE9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeMutableBytes",
+          "printedName": "withUnsafeMutableBytes(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "R"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafeMutableRawBufferPointer) throws -> R",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "R"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Paren",
+                  "printedName": "(UnsafeMutableRawBufferPointer)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafeMutableRawBufferPointer",
+                      "printedName": "UnsafeMutableRawBufferPointer",
+                      "usr": "s:Sw"
+                    }
+                  ],
+                  "usr": "s:Sw"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa22withUnsafeMutableBytesyqd__qd__SwKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, R>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeBytes",
+          "printedName": "withUnsafeBytes(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "R"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnsafeRawBufferPointer) throws -> R",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "R"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Paren",
+                  "printedName": "(UnsafeRawBufferPointer)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafeRawBufferPointer",
+                      "printedName": "UnsafeRawBufferPointer",
+                      "usr": "s:SW"
+                    }
+                  ],
+                  "usr": "s:SW"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sa15withUnsafeBytesyqd__qd__SWKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, R>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SasSERzlE6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Encodable>",
+          "throwing": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "Array<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:Sa"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SasSeRzlE4fromSayxGs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Decodable>",
+          "throwing": true
+        }
+      ],
       "declKind": "Struct",
       "usr": "s:Sa",
-      "location": "",
       "moduleName": "Swift",
       "genericSig": "<Element>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "_DestructorSafeContainer",
         "RandomAccessCollection",
@@ -448,1397 +1870,17 @@
         "Encodable",
         "Decodable",
         "_HasContiguousBytes"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:Sa5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:Sa7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Int>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:Sa8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "IndexingIterator",
-              "printedName": "IndexingIterator<Array<Element>>",
-              "usr": "s:s16IndexingIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Array",
-                  "printedName": "Array<Element>",
-                  "usr": "s:Sa",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:Sa10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sa10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:Sa8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sa8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:Sa5index5afterS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:Sa9formIndex5afterySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:Sa5index6beforeS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:Sa9formIndex6beforeySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:Sa5index_8offsetByS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:Sa5index_8offsetBy07limitedC0SiSgSi_S2itF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:Sa8distance4from2toS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:Sa7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:Sa11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ArraySlice",
-              "printedName": "ArraySlice<Element>",
-              "usr": "s:s10ArraySliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(arrayLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Sa12arrayLiteralSayxGxd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "Array<Element>",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "[Array<Element>.Element]",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Array<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "ArrayLiteralElement",
-          "printedName": "ArrayLiteralElement",
-          "declKind": "TypeAlias",
-          "usr": "s:Sa19ArrayLiteralElementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:S2ayxGycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "Array<Element>",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SaySayxGqd__c7ElementQyd__RszSTRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "Array<Element>",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(repeating:count:)",
-          "declKind": "Constructor",
-          "usr": "s:Sa9repeating5countSayxGx_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "Array<Element>",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "Array<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "count",
-          "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:Sa5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sa5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "capacity",
-          "printedName": "capacity",
-          "declKind": "Var",
-          "usr": "s:Sa8capacitySivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sa8capacitySivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "reserveCapacity",
-          "printedName": "reserveCapacity(_:)",
-          "declKind": "Func",
-          "usr": "s:Sa15reserveCapacityyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "append",
-          "printedName": "append(_:)",
-          "declKind": "Func",
-          "usr": "s:Sa6appendyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "Array<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "append",
-          "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:Sa6append10contentsOfyqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "remove",
-          "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:Sa6remove2atxSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "Array<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "insert",
-          "printedName": "insert(_:at:)",
-          "declKind": "Func",
-          "usr": "s:Sa6insert_2atyx_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "Array<Element>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "removeAll",
-          "printedName": "removeAll(keepingCapacity:)",
-          "declKind": "Func",
-          "usr": "s:Sa9removeAll15keepingCapacityySb_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "hasDefaultArg": true,
-              "usr": "s:Sb"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Sa12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sa12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "description",
-          "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:Sa11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sa11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "debugDescription",
-          "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Sa16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sa16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeBufferPointer",
-          "printedName": "withUnsafeBufferPointer(_:)",
-          "declKind": "Func",
-          "usr": "s:Sa23withUnsafeBufferPointeryqd__qd__SRyxGKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafeBufferPointer<Array<Element>.Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeBufferPointer<Array<Element>.Element>)",
-                  "usr": "s:SR",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeBufferPointer",
-                      "printedName": "UnsafeBufferPointer<Array<Element>.Element>",
-                      "usr": "s:SR",
-                      "children": [
-                        {
-                          "kind": "TypeNameAlias",
-                          "name": "Element",
-                          "printedName": "Array<Element>.Element",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "GenericTypeParam",
-                              "printedName": "τ_0_0"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeMutableBufferPointer",
-          "printedName": "withUnsafeMutableBufferPointer(_:)",
-          "declKind": "Func",
-          "usr": "s:Sa30withUnsafeMutableBufferPointeryqd__qd__SryxGzKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inline",
-            "Semantics"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(inout UnsafeMutableBufferPointer<Array<Element>.Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(inout UnsafeMutableBufferPointer<Array<Element>.Element>)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "InOut",
-                      "printedName": "inout UnsafeMutableBufferPointer<Array<Element>.Element>"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "replaceSubrange",
-          "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:Sa15replaceSubrange_4withySnySiG_qd__t7ElementQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, C where Element == C.Element, C : Collection>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Int>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "C"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "hash",
-          "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SasSHRzlE4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Hasher",
-              "printedName": "Hasher",
-              "usr": "s:s6HasherV"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "hashValue",
-          "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SasSHRzlE9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SasSHRzlE9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeMutableBytes",
-          "printedName": "withUnsafeMutableBytes(_:)",
-          "declKind": "Func",
-          "usr": "s:Sa22withUnsafeMutableBytesyqd__qd__SwKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafeMutableRawBufferPointer) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeMutableRawBufferPointer)",
-                  "usr": "s:Sw",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeMutableRawBufferPointer",
-                      "printedName": "UnsafeMutableRawBufferPointer",
-                      "usr": "s:Sw"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeBytes",
-          "printedName": "withUnsafeBytes(_:)",
-          "declKind": "Func",
-          "usr": "s:Sa15withUnsafeBytesyqd__qd__SWKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "R"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(UnsafeRawBufferPointer) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "R"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(UnsafeRawBufferPointer)",
-                  "usr": "s:SW",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnsafeRawBufferPointer",
-                      "printedName": "UnsafeRawBufferPointer",
-                      "usr": "s:SW"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:SasSERzlE6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Encodable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:SasSeRzlE4fromSayxGs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Decodable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "Array<Element>",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
-        }
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "ArraySlice",
       "printedName": "ArraySlice",
-      "declKind": "Struct",
-      "usr": "s:s10ArraySliceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "_DestructorSafeContainer",
-        "RandomAccessCollection",
-        "MutableCollection",
-        "BidirectionalCollection",
-        "Collection",
-        "Sequence",
-        "ExpressibleByArrayLiteral",
-        "RangeReplaceableCollection",
-        "ArrayProtocol",
-        "CustomReflectable",
-        "CustomStringConvertible",
-        "CustomDebugStringConvertible",
-        "Equatable",
-        "Hashable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s10ArraySliceV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -1846,23 +1888,21 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s10ArraySliceV5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s10ArraySliceV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Int>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -1870,54 +1910,51 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s10ArraySliceV7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s10ArraySliceV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "IndexingIterator",
               "printedName": "IndexingIterator<ArraySlice<Element>>",
-              "usr": "s:s16IndexingIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ArraySlice",
                   "printedName": "ArraySlice<Element>",
-                  "usr": "s:s10ArraySliceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s10ArraySliceV"
                 }
-              ]
+              ],
+              "usr": "s:s16IndexingIteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s10ArraySliceV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s10ArraySliceV10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -1929,11 +1966,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10ArraySliceV10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -1941,21 +1973,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10ArraySliceV10startIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10ArraySliceV10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s10ArraySliceV8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -1967,11 +2002,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10ArraySliceV8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -1979,22 +2009,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10ArraySliceV8endIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10ArraySliceV8endIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV5index5afterS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -2008,20 +2040,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV5index5afterS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV9formIndex5afterySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -2034,20 +2065,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV9formIndex5afterySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV5index6beforeS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -2061,20 +2091,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV5index6beforeS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV9formIndex6beforeySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -2087,20 +2116,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV9formIndex6beforeySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV5index_8offsetByS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -2120,26 +2148,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV5index_8offsetByS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV5index_8offsetBy07limitedE0SiSgSi_S2itF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -2147,7 +2173,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -2167,20 +2194,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV5index_8offsetBy07limitedE0SiSgSi_S2itF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV8distance4from2toS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -2200,81 +2226,147 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV8distance4from2toS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s10ArraySliceVyxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ArraySlice",
+              "printedName": "ArraySlice<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:s10ArraySliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s10ArraySliceVyAByxGSnySiGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s10ArraySliceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s10ArraySliceV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s10ArraySliceV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ArraySlice",
               "printedName": "ArraySlice<Element>",
-              "usr": "s:s10ArraySliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s10ArraySliceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s10ArraySliceV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(arrayLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s10ArraySliceV12arrayLiteralAByxGxd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ArraySlice",
               "printedName": "ArraySlice<Element>",
-              "usr": "s:s10ArraySliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s10ArraySliceV"
             },
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[ArraySlice<Element>.Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -2288,115 +2380,112 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s10ArraySliceV12arrayLiteralAByxGxd_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "ArrayLiteralElement",
           "printedName": "ArrayLiteralElement",
-          "declKind": "TypeAlias",
-          "usr": "s:s10ArraySliceV0A14LiteralElementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s10ArraySliceV0A14LiteralElementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s10ArraySliceVAByxGycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ArraySlice",
               "printedName": "ArraySlice<Element>",
-              "usr": "s:s10ArraySliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s10ArraySliceV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s10ArraySliceVAByxGycfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s10ArraySliceVyAByxGqd__c7ElementQyd__RszSTRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ArraySlice",
               "printedName": "ArraySlice<Element>",
-              "usr": "s:s10ArraySliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s10ArraySliceV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s10ArraySliceVyAByxGqd__c7ElementQyd__RszSTRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(repeating:count:)",
-          "declKind": "Constructor",
-          "usr": "s:s10ArraySliceV9repeating5countAByxGx_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ArraySlice",
               "printedName": "ArraySlice<Element>",
-              "usr": "s:s10ArraySliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s10ArraySliceV"
             },
             {
               "kind": "TypeNameAlias",
@@ -2416,19 +2505,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s10ArraySliceV9repeating5countAByxGx_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s10ArraySliceV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -2440,11 +2530,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10ArraySliceV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -2452,21 +2537,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10ArraySliceV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10ArraySliceV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "capacity",
           "printedName": "capacity",
-          "declKind": "Var",
-          "usr": "s:s10ArraySliceV8capacitySivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -2478,11 +2566,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10ArraySliceV8capacitySivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -2490,24 +2573,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10ArraySliceV8capacitySivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10ArraySliceV8capacitySivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "reserveCapacity",
           "printedName": "reserveCapacity(_:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV15reserveCapacityyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -2520,22 +2603,21 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV15reserveCapacityyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(_:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV6appendyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -2554,22 +2636,21 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV6appendyyxnF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV6append10contentsOfyqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -2581,22 +2662,21 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV6append10contentsOfyqd__n_t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "remove",
           "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV6remove2atxSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -2616,21 +2696,21 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV6remove2atxSi_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(_:at:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV6insert_2atyx_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -2655,21 +2735,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV6insert_2atyxn_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeAll",
           "printedName": "removeAll(keepingCapacity:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV9removeAll15keepingCapacityySb_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -2683,16 +2762,20 @@
               "hasDefaultArg": true,
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV9removeAll15keepingCapacityySb_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s10ArraySliceV12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -2704,11 +2787,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10ArraySliceV12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -2716,18 +2794,21 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10ArraySliceV12customMirrors0D0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s10ArraySliceV12customMirrors0D0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:s10ArraySliceV11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -2739,11 +2820,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10ArraySliceV11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -2751,18 +2827,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10ArraySliceV11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s10ArraySliceV11descriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s10ArraySliceV16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -2774,11 +2853,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10ArraySliceV16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -2786,24 +2860,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10ArraySliceV16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s10ArraySliceV16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "withUnsafeBufferPointer",
           "printedName": "withUnsafeBufferPointer(_:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV23withUnsafeBufferPointeryqd__qd__SRyxGKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -2814,9 +2885,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafeBufferPointer<ArraySlice<Element>.Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -2827,13 +2895,11 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafeBufferPointer<ArraySlice<Element>.Element>)",
-                  "usr": "s:SR",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafeBufferPointer",
                       "printedName": "UnsafeBufferPointer<ArraySlice<Element>.Element>",
-                      "usr": "s:SR",
                       "children": [
                         {
                           "kind": "TypeNameAlias",
@@ -2847,30 +2913,32 @@
                             }
                           ]
                         }
-                      ]
+                      ],
+                      "usr": "s:SR"
                     }
-                  ]
+                  ],
+                  "usr": "s:SR"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV23withUnsafeBufferPointeryqd__qd__SRyxGKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, R>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "withUnsafeMutableBufferPointer",
           "printedName": "withUnsafeMutableBufferPointer(_:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV30withUnsafeMutableBufferPointeryqd__qd__SryxGzKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inline",
-            "Semantics"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -2881,9 +2949,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(inout UnsafeMutableBufferPointer<ArraySlice<Element>.Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -2902,24 +2967,28 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV30withUnsafeMutableBufferPointeryqd__qd__SryxGzKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, R>",
+          "declAttributes": [
+            "Rethrows",
+            "Inline",
+            "Semantics"
+          ],
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "replaceSubrange",
           "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV15replaceSubrange_4withySnySiG_qd__t7ElementQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, C where Element == C.Element, C : Collection>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -2930,7 +2999,6 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Int>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -2938,27 +3006,90 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "C"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV15replaceSubrange_4withySnySiG_qd__nt7ElementQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, C where Element == C.Element, C : Collection>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ArraySlice",
+              "printedName": "ArraySlice<ArraySlice<Element>.Element>",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Element",
+                  "printedName": "ArraySlice<Element>.Element",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:s10ArraySliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ArraySlice",
+              "printedName": "ArraySlice<ArraySlice<Element>.Element>",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Element",
+                  "printedName": "ArraySlice<Element>.Element",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:s10ArraySliceV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceVsSQRzlE2eeoiySbAByxG_ADtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Equatable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceVsSHRzlE4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -2971,16 +3102,19 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceVsSHRzlE4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s10ArraySliceVsSHRzlE9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -2992,11 +3126,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10ArraySliceVsSHRzlE9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -3004,25 +3133,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10ArraySliceVsSHRzlE9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s10ArraySliceVsSHRzlE9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "withUnsafeMutableBytes",
           "printedName": "withUnsafeMutableBytes(_:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV22withUnsafeMutableBytesyqd__qd__SwKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3033,9 +3160,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafeMutableRawBufferPointer) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -3046,7 +3170,6 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafeMutableRawBufferPointer)",
-                  "usr": "s:Sw",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -3054,26 +3177,30 @@
                       "printedName": "UnsafeMutableRawBufferPointer",
                       "usr": "s:Sw"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sw"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV22withUnsafeMutableBytesyqd__qd__SwKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, R>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "withUnsafeBytes",
           "printedName": "withUnsafeBytes(_:)",
-          "declKind": "Func",
-          "usr": "s:s10ArraySliceV15withUnsafeBytesyqd__qd__SWKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3084,9 +3211,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafeRawBufferPointer) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -3097,7 +3221,6 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafeRawBufferPointer)",
-                  "usr": "s:SW",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -3105,25 +3228,54 @@
                       "printedName": "UnsafeRawBufferPointer",
                       "usr": "s:SW"
                     }
-                  ]
+                  ],
+                  "usr": "s:SW"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10ArraySliceV15withUnsafeBytesyqd__qd__SWKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, R>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s10ArraySliceV",
+      "moduleName": "Swift",
+      "genericSig": "<Element>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "_DestructorSafeContainer",
+        "RandomAccessCollection",
+        "MutableCollection",
+        "BidirectionalCollection",
+        "Collection",
+        "Sequence",
+        "ExpressibleByArrayLiteral",
+        "RangeReplaceableCollection",
+        "ArrayProtocol",
+        "CustomReflectable",
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible",
+        "Equatable",
+        "Hashable"
       ]
     },
     {
       "kind": "Function",
       "name": "assert",
       "printedName": "assert(_:_:file:line:)",
-      "declKind": "Func",
-      "usr": "s:s6assert__4file4lineySbyXK_SSyXKs12StaticStringVSutF",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Transparent"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -3134,9 +3286,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "() -> Bool",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3149,15 +3298,15 @@
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         },
         {
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "() -> String",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3170,6 +3319,9 @@
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         },
         {
@@ -3186,19 +3338,18 @@
           "hasDefaultArg": true,
           "usr": "s:Su"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s6assert__4file4lineySbyXK_SSyXKs12StaticStringVSutF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Transparent"
       ]
     },
     {
       "kind": "Function",
       "name": "precondition",
       "printedName": "precondition(_:_:file:line:)",
-      "declKind": "Func",
-      "usr": "s:s12precondition__4file4lineySbyXK_SSyXKs12StaticStringVSutF",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Transparent"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -3209,9 +3360,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "() -> Bool",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3224,15 +3372,15 @@
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         },
         {
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "() -> String",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3245,6 +3393,9 @@
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         },
         {
@@ -3261,20 +3412,18 @@
           "hasDefaultArg": true,
           "usr": "s:Su"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s12precondition__4file4lineySbyXK_SSyXKs12StaticStringVSutF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Transparent"
       ]
     },
     {
       "kind": "Function",
       "name": "assertionFailure",
       "printedName": "assertionFailure(_:file:line:)",
-      "declKind": "Func",
-      "usr": "s:s16assertionFailure_4file4lineySSyXK_s12StaticStringVSutF",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Inline",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -3285,9 +3434,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "() -> String",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3300,6 +3446,9 @@
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         },
         {
@@ -3316,19 +3465,19 @@
           "hasDefaultArg": true,
           "usr": "s:Su"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s16assertionFailure_4file4lineySSyXK_s12StaticStringVSutF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inline",
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "preconditionFailure",
       "printedName": "preconditionFailure(_:file:line:)",
-      "declKind": "Func",
-      "usr": "s:s19preconditionFailure_4file4lines5NeverOSSyXK_s12StaticStringVSutF",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Transparent"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -3340,9 +3489,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "() -> String",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3355,6 +3501,9 @@
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         },
         {
@@ -3371,19 +3520,18 @@
           "hasDefaultArg": true,
           "usr": "s:Su"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s19preconditionFailure_4file4lines5NeverOSSyXK_s12StaticStringVSutF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Transparent"
       ]
     },
     {
       "kind": "Function",
       "name": "fatalError",
       "printedName": "fatalError(_:file:line:)",
-      "declKind": "Func",
-      "usr": "s:s10fatalError_4file4lines5NeverOSSyXK_s12StaticStringVSutF",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Transparent"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -3395,9 +3543,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "() -> String",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3410,6 +3555,9 @@
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         },
         {
@@ -3426,31 +3574,63 @@
           "hasDefaultArg": true,
           "usr": "s:Su"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s10fatalError_4file4lines5NeverOSSyXK_s12StaticStringVSutF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Transparent"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "BidirectionalCollection",
       "printedName": "BidirectionalCollection",
-      "declKind": "Protocol",
-      "usr": "s:SK",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Collection, Self.Indices : BidirectionalCollection, Self.SubSequence : BidirectionalCollection>",
-      "conformingProtocols": [
-        "Collection",
-        "Sequence"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Element",
+          "printedName": "Element",
+          "declKind": "AssociatedType",
+          "usr": "s:SK7ElementQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Index",
+          "printedName": "Index",
+          "declKind": "AssociatedType",
+          "usr": "s:SK5IndexQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "declKind": "AssociatedType",
+          "usr": "s:SK11SubSequenceQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Indices",
+          "printedName": "Indices",
+          "declKind": "AssociatedType",
+          "usr": "s:SK7IndicesQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:SK5index6before5IndexQzAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -3462,17 +3642,17 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SK5index6before5IndexQzAD_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:SK9formIndex6beforey0B0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -3484,17 +3664,17 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SK9formIndex6beforey0B0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:SK5index5after5IndexQzAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -3506,17 +3686,21 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SK5index5after5IndexQzAD_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:SK9formIndex5aftery0B0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -3528,17 +3712,21 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SK9formIndex5aftery0B0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SK5index_8offsetBy5IndexQzAD_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -3556,30 +3744,30 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SK5index_8offsetBy5IndexQzAD_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SK5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -3597,17 +3785,17 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SK5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SK8distance4from2toSi5IndexQz_AEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -3625,16 +3813,17 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SK8distance4from2toSi5IndexQz_AEtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:SK7indices7IndicesQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -3645,78 +3834,144 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SK7indices7IndicesQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Indices"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SK7indices7IndicesQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : BidirectionalCollection>",
+              "overriding": true,
+              "declAttributes": [
+                "Override"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SK7indices7IndicesQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Var",
           "name": "last",
           "printedName": "last",
-          "declKind": "Var",
-          "usr": "s:SK4last7ElementQzSgvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SK4last7ElementQzSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Self.Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Self.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SK4last7ElementQzSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : BidirectionalCollection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SK4last7ElementQzSgvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.SubSequence"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Self.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "Self.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SKy11SubSequenceQzSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Index"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SKy7ElementQz5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:SK10startIndex0B0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -3727,29 +3982,36 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SK10startIndex0B0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SK10startIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : BidirectionalCollection>",
+              "overriding": true,
+              "declAttributes": [
+                "Override"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SK10startIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:SK8endIndex0B0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -3760,34 +4022,36 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SK8endIndex0B0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SK8endIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : BidirectionalCollection>",
+              "overriding": true,
+              "declAttributes": [
+                "Override"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SK8endIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:SKsE9formIndex6beforey0B0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3799,20 +4063,20 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE9formIndex6beforey0B0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SKsE5index_8offsetBy5IndexQzAD_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3830,33 +4094,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE5index_8offsetBy5IndexQzAD_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SKsE5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -3874,20 +4137,19 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SKsE8distance4from2toSi5IndexQz_AEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3905,72 +4167,68 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE8distance4from2toSi5IndexQz_AEtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "popLast",
           "printedName": "popLast()",
-          "declKind": "Func",
-          "usr": "s:SKs11SubSequenceQzRszrlE7popLast7ElementQzSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SKs11SubSequenceQzRszrlE7popLast7ElementQzSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection, Self == Self.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeLast",
           "printedName": "removeLast()",
-          "declKind": "Func",
-          "usr": "s:SKs11SubSequenceQzRszrlE10removeLast7ElementQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SKs11SubSequenceQzRszrlE10removeLast7ElementQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection, Self == Self.SubSequence>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeLast",
           "printedName": "removeLast(_:)",
-          "declKind": "Func",
-          "usr": "s:SKs11SubSequenceQzRszrlE10removeLastyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -3983,20 +4241,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SKs11SubSequenceQzRszrlE10removeLastyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection, Self == Self.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:SKsE8dropLasty11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4009,20 +4267,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE8dropLasty11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:SKsE6suffixy11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4035,95 +4292,87 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE6suffixy11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "last",
           "printedName": "last",
-          "declKind": "Var",
-          "usr": "s:SKsE4last7ElementQzSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SKsE4last7ElementQzSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Self.Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Self.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SKsE4last7ElementQzSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : BidirectionalCollection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SKsE4last7ElementQzSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "last",
           "printedName": "last(where:)",
-          "declKind": "Func",
-          "usr": "s:SKsE4last5where7ElementQzSgSbADKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -4143,45 +4392,44 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE4last5where7ElementQzSgSbADKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "lastIndex",
           "printedName": "lastIndex(where:)",
-          "declKind": "Func",
-          "usr": "s:SKsE9lastIndex5where0B0QzSgSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -4201,83 +4449,85 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE9lastIndex5where0B0QzSgSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "lastIndex",
           "printedName": "lastIndex(of:)",
-          "declKind": "Func",
-          "usr": "s:SKsSQ7ElementRpzrlE9lastIndex2of0C0QzSgAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self.Element : Equatable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsSQ7ElementRpzrlE9lastIndex2of0C0QzSgAB_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection, Self.Element : Equatable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "reversed",
           "printedName": "reversed()",
-          "declKind": "Func",
-          "usr": "s:SKsE8reverseds18ReversedCollectionVyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ReversedCollection",
               "printedName": "ReversedCollection<Self>",
-              "usr": "s:s18ReversedCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:s18ReversedCollectionV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsE8reverseds18ReversedCollectionVyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "joined",
           "printedName": "joined(separator:)",
-          "declKind": "Func",
-          "usr": "s:SKsSS7ElementRtzrlE6joined9separatorS2S_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self.Element == String>",
-          "declAttributes": [
-            "Specialize"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4292,46 +4542,34 @@
               "hasDefaultArg": true,
               "usr": "s:SS"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SKsSS7ElementRtzrlE6joined9separatorS2S_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection, Self.Element == String>",
+          "declAttributes": [
+            "Specialize"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SK",
+      "moduleName": "Swift",
+      "genericSig": "<Self : Collection, Self.Indices : BidirectionalCollection, Self.SubSequence : BidirectionalCollection>",
+      "conformingProtocols": [
+        "Collection",
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Bool",
       "printedName": "Bool",
-      "declKind": "Struct",
-      "usr": "s:Sb",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "_ExpressibleByBuiltinBooleanLiteral",
-        "ExpressibleByBooleanLiteral",
-        "CustomStringConvertible",
-        "Equatable",
-        "Hashable",
-        "LosslessStringConvertible",
-        "Decodable",
-        "Encodable",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:S2bycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4339,20 +4577,18 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:S2bycfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SbySbBi1_cfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "UsableFromInline"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4372,19 +4608,20 @@
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SbySbBi1_cfc",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "Transparent",
+            "UsableFromInline"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SbyS2bcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4398,21 +4635,18 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SbyS2bcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "random",
           "printedName": "random(using:)",
-          "declKind": "Func",
-          "usr": "s:Sb6random5usingSbxz_tSGRzlFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T where T : RandomNumberGenerator>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4425,20 +4659,20 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb6random5usingSbxz_tSGRzlFZ",
+          "moduleName": "Swift",
+          "genericSig": "<T where T : RandomNumberGenerator>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "random",
           "printedName": "random()",
-          "declKind": "Func",
-          "usr": "s:Sb6randomSbyFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4446,19 +4680,19 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb6randomSbyFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(booleanLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Sb14booleanLiteralS2b_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4472,16 +4706,18 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sb14booleanLiteralS2b_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "BooleanLiteralType",
           "printedName": "BooleanLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Sb18BooleanLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -4489,19 +4725,16 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sb18BooleanLiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:Sb11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4513,10 +4746,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sb11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -4524,21 +4753,55 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sb11descriptionSSvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sb11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb2eeoiyS2b_SbtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:Sb4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4551,16 +4814,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Sb9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -4572,10 +4837,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sb9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -4583,27 +4844,27 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sb9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sb9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SbySbSgSScfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Bool?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -4611,7 +4872,8 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -4619,40 +4881,164 @@
               "printedName": "String",
               "usr": "s:SS"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SbySbSgSScfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
+          "name": "!",
+          "printedName": "!(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb1nopyS2bFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&&",
+          "printedName": "&&(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "() throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb2aaoiyS2b_SbyKXKtKFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Rethrows",
+            "Inline",
+            "Transparent"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "||",
+          "printedName": "||(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "() throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb2oooiyS2b_SbyKXKtKFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Rethrows",
+            "Inline",
+            "Transparent"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
           "name": "toggle",
           "printedName": "toggle()",
-          "declKind": "Func",
-          "usr": "s:Sb6toggleyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb6toggleyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:Sb4fromSbs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4666,20 +5052,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sb4fromSbs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:Sb6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4692,16 +5074,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sb6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Sb12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -4713,10 +5095,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sb12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -4724,23 +5102,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sb12customMirrors0B0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sb12customMirrors0B0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:Sb25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4752,10 +5127,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sb25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -4763,46 +5134,50 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sb25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sb25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:Sb",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "_ExpressibleByBuiltinBooleanLiteral",
+        "ExpressibleByBooleanLiteral",
+        "CustomStringConvertible",
+        "Equatable",
+        "Hashable",
+        "LosslessStringConvertible",
+        "Encodable",
+        "Decodable",
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AutoreleasingUnsafeMutablePointer",
       "printedName": "AutoreleasingUnsafeMutablePointer",
-      "declKind": "Struct",
-      "usr": "s:SA",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Pointee>",
-      "conformingProtocols": [
-        "_Pointer",
-        "Hashable",
-        "Strideable",
-        "CustomDebugStringConvertible",
-        "CustomReflectable",
-        "Equatable",
-        "Comparable",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "pointee",
           "printedName": "pointee",
-          "declKind": "Var",
-          "usr": "s:SA7pointeexvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -4813,34 +5188,25 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SA7pointeexvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Pointee>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Pointee"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SA7pointeexvg",
+              "moduleName": "Swift",
+              "genericSig": "<Pointee>",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Setter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SA7pointeexvs",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Pointee>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -4852,135 +5218,169 @@
                   "name": "GenericTypeParam",
                   "printedName": "Pointee"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SA7pointeexvs",
+              "moduleName": "Swift",
+              "genericSig": "<Pointee>",
+              "declAttributes": [
+                "Transparent"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SA7pointeexvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Pointee"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SAyxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SAySAyxGSPyqd__Gclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee, U>",
-          "declAttributes": [
-            "Transparent",
-            "UsableFromInline"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AutoreleasingUnsafeMutablePointer",
               "printedName": "AutoreleasingUnsafeMutablePointer<Pointee>",
-              "usr": "s:SA",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Pointee"
                 }
-              ]
+              ],
+              "usr": "s:SA"
             },
             {
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<U>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "U"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SAySAyxGSPyqd__Gclufc",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee, U>",
+          "isInternal": true,
+          "declAttributes": [
+            "Transparent",
+            "UsableFromInline"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SAySAyxGSgSPyqd__GSgclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee, U>",
-          "declAttributes": [
-            "Transparent",
-            "UsableFromInline"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "AutoreleasingUnsafeMutablePointer<Pointee>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AutoreleasingUnsafeMutablePointer",
                   "printedName": "AutoreleasingUnsafeMutablePointer<Pointee>",
-                  "usr": "s:SA",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Pointee"
                     }
-                  ]
+                  ],
+                  "usr": "s:SA"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafePointer<U>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafePointer",
                   "printedName": "UnsafePointer<U>",
-                  "usr": "s:SP",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "U"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SAySAyxGSgSPyqd__GSgclufc",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee, U>",
+          "isInternal": true,
+          "declAttributes": [
+            "Transparent",
+            "UsableFromInline"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Pointee",
           "printedName": "Pointee",
-          "declKind": "TypeAlias",
-          "usr": "s:SA7Pointeea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Pointee"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SA7Pointeea",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SA9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -4992,11 +5392,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SA9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Pointee>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -5004,19 +5399,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SA9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Pointee>",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SA9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:SA6Stridea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -5024,23 +5423,36 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SA6Stridea",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:SA",
+      "moduleName": "Swift",
+      "genericSig": "<Pointee>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "_Pointer",
+        "Hashable",
+        "Strideable",
+        "CustomDebugStringConvertible",
+        "CustomReflectable",
+        "Equatable",
+        "Comparable",
+        "CVarArg"
       ]
     },
     {
       "kind": "Function",
       "name": "unsafeBitCast",
       "printedName": "unsafeBitCast(_:to:)",
-      "declKind": "Func",
-      "usr": "s:s13unsafeBitCast_2toq_x_q_mtr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, U>",
-      "declAttributes": [
-        "Transparent",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -5064,20 +5476,138 @@
             }
           ]
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s13unsafeBitCast_2toq_x_q_mtr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<T, U>",
+      "declAttributes": [
+        "Transparent",
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "==",
+      "printedName": "==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "Any.Type?",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ExistentialMetatype",
+              "printedName": "Any.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ProtocolComposition",
+                  "printedName": "Any"
+                }
+              ]
+            }
+          ],
+          "usr": "s:Sq"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "Any.Type?",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ExistentialMetatype",
+              "printedName": "Any.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ProtocolComposition",
+                  "printedName": "Any"
+                }
+              ]
+            }
+          ],
+          "usr": "s:Sq"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2eeoiySbypXpSg_ABtF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "Any.Type?",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ExistentialMetatype",
+              "printedName": "Any.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ProtocolComposition",
+                  "printedName": "Any"
+                }
+              ]
+            }
+          ],
+          "usr": "s:Sq"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "Any.Type?",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ExistentialMetatype",
+              "printedName": "Any.Type",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ProtocolComposition",
+                  "printedName": "Any"
+                }
+              ]
+            }
+          ],
+          "usr": "s:Sq"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbypXpSg_ABtF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "unsafeDowncast",
       "printedName": "unsafeDowncast(_:to:)",
-      "declKind": "Func",
-      "usr": "s:s14unsafeDowncast_2toxyXl_xmtRlzClF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : AnyObject>",
-      "declAttributes": [
-        "Transparent"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -5108,21 +5638,19 @@
             }
           ]
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s14unsafeDowncast_2toxyXl_xmtRlzClF",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : AnyObject>",
+      "declAttributes": [
+        "Transparent"
       ]
     },
     {
       "kind": "Function",
       "name": "type",
       "printedName": "type(of:)",
-      "declKind": "Func",
-      "usr": "s:s4type2ofq_x_tr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, Metatype>",
-      "declAttributes": [
-        "Semantics",
-        "Transparent"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -5134,23 +5662,20 @@
           "name": "GenericTypeParam",
           "printedName": "T"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s4type2ofq_x_tr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<T, Metatype>",
+      "declAttributes": [
+        "Semantics",
+        "Transparent"
       ]
     },
     {
       "kind": "Function",
       "name": "withoutActuallyEscaping",
       "printedName": "withoutActuallyEscaping(_:do:)",
-      "declKind": "Func",
-      "usr": "s:s23withoutActuallyEscaping_2doq_x_q_xKXEtKr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<ClosureType, ResultType>",
-      "throwing": true,
-      "declAttributes": [
-        "Rethrows",
-        "Semantics",
-        "Transparent"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -5166,9 +5691,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "(ClosureType) throws -> ResultType",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -5187,18 +5709,874 @@
                 }
               ]
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         }
-      ]
+      ],
+      "declKind": "Func",
+      "usr": "s:s23withoutActuallyEscaping_2doq_x_q_xKXEtKr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<ClosureType, ResultType>",
+      "declAttributes": [
+        "Rethrows",
+        "Semantics",
+        "Transparent"
+      ],
+      "throwing": true
     },
     {
       "kind": "TypeDecl",
       "name": "Character",
       "printedName": "Character",
+      "children": [
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Scalar",
+              "printedName": "Unicode.Scalar",
+              "usr": "s:s7UnicodeO6ScalarV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SJySJs7UnicodeO6ScalarVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(extendedGraphemeClusterLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SJ30extendedGraphemeClusterLiteralS2J_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SJySJSScfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "ExtendedGraphemeClusterLiteralType",
+          "printedName": "ExtendedGraphemeClusterLiteralType",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SJ34ExtendedGraphemeClusterLiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "UnicodeScalarLiteralType",
+          "printedName": "UnicodeScalarLiteralType",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SJ24UnicodeScalarLiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Var",
+          "name": "description",
+          "printedName": "description",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SJ11descriptionSSvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SJ11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SJ16debugDescriptionSSvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SJ16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SJ2eeoiySbSJ_SJtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SJ1loiySbSJ_SJtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "hash",
+          "printedName": "hash(into:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Hasher",
+              "printedName": "Hasher",
+              "usr": "s:s6HasherV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SJ4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Effects"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "hashValue",
+          "printedName": "hashValue",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SJ9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SJ9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "UnicodeScalarView",
+          "printedName": "UnicodeScalarView",
+          "children": [
+            {
+              "kind": "TypeDecl",
+              "name": "Iterator",
+              "printedName": "Iterator",
+              "children": [
+                {
+                  "kind": "Function",
+                  "name": "next",
+                  "printedName": "next()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "UnicodeScalar?",
+                      "children": [
+                        {
+                          "kind": "TypeNameAlias",
+                          "name": "UnicodeScalar",
+                          "printedName": "UnicodeScalar",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "Scalar",
+                              "printedName": "Unicode.Scalar",
+                              "usr": "s:s7UnicodeO6ScalarV"
+                            }
+                          ]
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SJ17UnicodeScalarViewV8IteratorV4nexts0A0O0B0VSgyF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ],
+                  "mutating": true
+                },
+                {
+                  "kind": "TypeAlias",
+                  "name": "Element",
+                  "printedName": "Element",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Scalar",
+                      "printedName": "Unicode.Scalar",
+                      "usr": "s:s7UnicodeO6ScalarV"
+                    }
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:SJ17UnicodeScalarViewV8IteratorV7Elementa",
+                  "moduleName": "Swift",
+                  "implicit": true
+                }
+              ],
+              "declKind": "Struct",
+              "usr": "s:SJ17UnicodeScalarViewV8IteratorV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "IteratorProtocol"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "makeIterator",
+              "printedName": "makeIterator()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Iterator",
+                  "printedName": "Character.UnicodeScalarView.Iterator",
+                  "usr": "s:SJ17UnicodeScalarViewV8IteratorV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SJ17UnicodeScalarViewV12makeIteratorAB0E0VyF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "TypeDecl",
+              "name": "Index",
+              "printedName": "Index",
+              "children": [
+                {
+                  "kind": "Function",
+                  "name": "==",
+                  "printedName": "==(_:_:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Character.UnicodeScalarView.Index",
+                      "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Character.UnicodeScalarView.Index",
+                      "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV2eeoiySbAD_ADtFZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "<",
+                  "printedName": "<(_:_:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Character.UnicodeScalarView.Index",
+                      "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Character.UnicodeScalarView.Index",
+                      "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV1loiySbAD_ADtFZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                }
+              ],
+              "declKind": "Struct",
+              "usr": "s:SJ17UnicodeScalarViewV5IndexV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "Equatable",
+                "Comparable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "startIndex",
+              "printedName": "startIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Character.UnicodeScalarView.Index",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Character.UnicodeScalarView.Index",
+                      "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SJ17UnicodeScalarViewV10startIndexAB0E0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SJ17UnicodeScalarViewV10startIndexAB0E0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "endIndex",
+              "printedName": "endIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Character.UnicodeScalarView.Index",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Character.UnicodeScalarView.Index",
+                      "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SJ17UnicodeScalarViewV8endIndexAB0E0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SJ17UnicodeScalarViewV8endIndexAB0E0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Character.UnicodeScalarView.Index",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Character.UnicodeScalarView.Index",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SJ17UnicodeScalarViewV5index5afterAB5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "UnicodeScalar",
+                  "printedName": "UnicodeScalar",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Scalar",
+                      "printedName": "Unicode.Scalar",
+                      "usr": "s:s7UnicodeO6ScalarV"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Character.UnicodeScalarView.Index",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SJ17UnicodeScalarViewVys0A0O0B0VAB5IndexVcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "TypeAlias",
+              "name": "Element",
+              "printedName": "Element",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "UnicodeScalar",
+                  "printedName": "UnicodeScalar",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Scalar",
+                      "printedName": "Unicode.Scalar",
+                      "usr": "s:s7UnicodeO6ScalarV"
+                    }
+                  ]
+                }
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SJ17UnicodeScalarViewV7Elementa",
+              "moduleName": "Swift",
+              "implicit": true
+            },
+            {
+              "kind": "TypeAlias",
+              "name": "SubSequence",
+              "printedName": "SubSequence",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Slice",
+                  "printedName": "Slice<Character.UnicodeScalarView>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnicodeScalarView",
+                      "printedName": "Character.UnicodeScalarView",
+                      "usr": "s:SJ17UnicodeScalarViewV"
+                    }
+                  ],
+                  "usr": "s:s5SliceV"
+                }
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SJ17UnicodeScalarViewV11SubSequencea",
+              "moduleName": "Swift",
+              "implicit": true
+            },
+            {
+              "kind": "TypeAlias",
+              "name": "Indices",
+              "printedName": "Indices",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DefaultIndices",
+                  "printedName": "DefaultIndices<Character.UnicodeScalarView>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnicodeScalarView",
+                      "printedName": "Character.UnicodeScalarView",
+                      "usr": "s:SJ17UnicodeScalarViewV"
+                    }
+                  ],
+                  "usr": "s:SI"
+                }
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SJ17UnicodeScalarViewV7Indicesa",
+              "moduleName": "Swift",
+              "implicit": true
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(before:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Character.UnicodeScalarView.Index",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Character.UnicodeScalarView.Index",
+                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SJ17UnicodeScalarViewV5index6beforeAB5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SJ17UnicodeScalarViewV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "Sequence",
+            "Collection",
+            "BidirectionalCollection"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "unicodeScalars",
+          "printedName": "unicodeScalars",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnicodeScalarView",
+              "printedName": "Character.UnicodeScalarView",
+              "usr": "s:SJ17UnicodeScalarViewV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnicodeScalarView",
+                  "printedName": "Character.UnicodeScalarView",
+                  "usr": "s:SJ17UnicodeScalarViewV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SJ14unicodeScalarsSJ17UnicodeScalarViewVvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SJ14unicodeScalarsSJ17UnicodeScalarViewVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "customMirror",
+          "printedName": "customMirror",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Mirror",
+              "printedName": "Mirror",
+              "usr": "s:s6MirrorV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SJ12customMirrors0B0Vvg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SJ12customMirrors0B0Vvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "customPlaygroundQuickLook",
+          "printedName": "customPlaygroundQuickLook",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "_PlaygroundQuickLook",
+              "printedName": "_PlaygroundQuickLook",
+              "usr": "s:s20_PlaygroundQuickLookO"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "_PlaygroundQuickLook",
+                  "printedName": "_PlaygroundQuickLook",
+                  "usr": "s:s20_PlaygroundQuickLookO"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SJ25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SJ25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "write",
+          "printedName": "write(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Target"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SJ5write2toyxz_ts16TextOutputStreamRzlF",
+          "moduleName": "Swift",
+          "genericSig": "<Target where Target : TextOutputStream>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        }
+      ],
       "declKind": "Struct",
       "usr": "s:SJ",
-      "location": "",
       "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "_ExpressibleByBuiltinUTF16ExtendedGraphemeClusterLiteral",
         "ExpressibleByExtendedGraphemeClusterLiteral",
@@ -5214,734 +6592,17 @@
         "CustomReflectable",
         "_CustomPlaygroundQuickLookable",
         "TextOutputStreamable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SJySJs7UnicodeO6ScalarVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Scalar",
-              "printedName": "Unicode.Scalar",
-              "usr": "s:s7UnicodeO6ScalarV"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(extendedGraphemeClusterLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:SJ30extendedGraphemeClusterLiteralS2J_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SJySJSScfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "ExtendedGraphemeClusterLiteralType",
-          "printedName": "ExtendedGraphemeClusterLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:SJ34ExtendedGraphemeClusterLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "UnicodeScalarLiteralType",
-          "printedName": "UnicodeScalarLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:SJ24UnicodeScalarLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Character",
-              "printedName": "Character",
-              "usr": "s:SJ"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "description",
-          "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:SJ11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SJ11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "debugDescription",
-          "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:SJ16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SJ16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "hash",
-          "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SJ4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Effects"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Hasher",
-              "printedName": "Hasher",
-              "usr": "s:s6HasherV"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "hashValue",
-          "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SJ9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SJ9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeDecl",
-          "name": "UnicodeScalarView",
-          "printedName": "UnicodeScalarView",
-          "declKind": "Struct",
-          "usr": "s:SJ17UnicodeScalarViewV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "Sequence",
-            "Collection",
-            "BidirectionalCollection"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "TypeDecl",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "Struct",
-              "usr": "s:SJ17UnicodeScalarViewV8IteratorV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "IteratorProtocol"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
-              "children": [
-                {
-                  "kind": "Function",
-                  "name": "next",
-                  "printedName": "next()",
-                  "declKind": "Func",
-                  "usr": "s:SJ17UnicodeScalarViewV8IteratorV4nexts0A0O0B0VSgyF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "mutating": true,
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Optional",
-                      "printedName": "UnicodeScalar?",
-                      "usr": "s:Sq",
-                      "children": [
-                        {
-                          "kind": "TypeNameAlias",
-                          "name": "UnicodeScalar",
-                          "printedName": "UnicodeScalar",
-                          "children": [
-                            {
-                              "kind": "TypeNominal",
-                              "name": "Scalar",
-                              "printedName": "Unicode.Scalar",
-                              "usr": "s:s7UnicodeO6ScalarV"
-                            }
-                          ]
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeAlias",
-                  "name": "Element",
-                  "printedName": "Element",
-                  "declKind": "TypeAlias",
-                  "usr": "s:SJ17UnicodeScalarViewV8IteratorV7Elementa",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Scalar",
-                      "printedName": "Unicode.Scalar",
-                      "usr": "s:s7UnicodeO6ScalarV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "makeIterator",
-              "printedName": "makeIterator()",
-              "declKind": "Func",
-              "usr": "s:SJ17UnicodeScalarViewV12makeIteratorAB0E0VyF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Iterator",
-                  "printedName": "Character.UnicodeScalarView.Iterator",
-                  "usr": "s:SJ17UnicodeScalarViewV8IteratorV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeDecl",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "Struct",
-              "usr": "s:SJ17UnicodeScalarViewV5IndexV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "Equatable",
-                "Comparable"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "startIndex",
-              "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:SJ17UnicodeScalarViewV10startIndexAB0E0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Character.UnicodeScalarView.Index",
-                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SJ17UnicodeScalarViewV10startIndexAB0E0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "Character.UnicodeScalarView.Index",
-                      "usr": "s:SJ17UnicodeScalarViewV5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "endIndex",
-              "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:SJ17UnicodeScalarViewV8endIndexAB0E0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Character.UnicodeScalarView.Index",
-                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SJ17UnicodeScalarViewV8endIndexAB0E0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "Character.UnicodeScalarView.Index",
-                      "usr": "s:SJ17UnicodeScalarViewV5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SJ17UnicodeScalarViewV5index5afterAB5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Character.UnicodeScalarView.Index",
-                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Character.UnicodeScalarView.Index",
-                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:SJ17UnicodeScalarViewV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "UnicodeScalar",
-                  "printedName": "UnicodeScalar",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Scalar",
-                      "printedName": "Unicode.Scalar",
-                      "usr": "s:s7UnicodeO6ScalarV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:SJ17UnicodeScalarViewV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Slice",
-                  "printedName": "Slice<Character.UnicodeScalarView>",
-                  "usr": "s:s5SliceV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnicodeScalarView",
-                      "printedName": "Character.UnicodeScalarView",
-                      "usr": "s:SJ17UnicodeScalarViewV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:SJ17UnicodeScalarViewV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DefaultIndices",
-                  "printedName": "DefaultIndices<Character.UnicodeScalarView>",
-                  "usr": "s:SI",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "UnicodeScalarView",
-                      "printedName": "Character.UnicodeScalarView",
-                      "usr": "s:SJ17UnicodeScalarViewV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:SJ17UnicodeScalarViewV5index6beforeAB5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Character.UnicodeScalarView.Index",
-                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Character.UnicodeScalarView.Index",
-                  "usr": "s:SJ17UnicodeScalarViewV5IndexV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "unicodeScalars",
-          "printedName": "unicodeScalars",
-          "declKind": "Var",
-          "usr": "s:SJ14unicodeScalarsSJ17UnicodeScalarViewVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnicodeScalarView",
-              "printedName": "Character.UnicodeScalarView",
-              "usr": "s:SJ17UnicodeScalarViewV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SJ14unicodeScalarsSJ17UnicodeScalarViewVvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnicodeScalarView",
-                  "printedName": "Character.UnicodeScalarView",
-                  "usr": "s:SJ17UnicodeScalarViewV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:SJ12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SJ12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customPlaygroundQuickLook",
-          "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:SJ25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "_PlaygroundQuickLook",
-              "printedName": "_PlaygroundQuickLook",
-              "usr": "s:s20_PlaygroundQuickLookO"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SJ25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "_PlaygroundQuickLook",
-                  "printedName": "_PlaygroundQuickLook",
-                  "usr": "s:s20_PlaygroundQuickLookO"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "write",
-          "printedName": "write(to:)",
-          "declKind": "Func",
-          "usr": "s:SJ5write2toyxz_ts16TextOutputStreamRzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Target where Target : TextOutputStream>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Target"
-            }
-          ]
-        }
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Encodable",
       "printedName": "Encodable",
-      "declKind": "Protocol",
-      "usr": "s:SE",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:SE6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encodable>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -5954,29 +6615,28 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SE6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Encodable>",
+          "protocolReq": true,
+          "throwing": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SE",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "Decodable",
       "printedName": "Decodable",
-      "declKind": "Protocol",
-      "usr": "s:Se",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:Se4fromxs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -5989,48 +6649,43 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Se4fromxs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Decodable>",
+          "protocolReq": true,
+          "throwing": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:Se",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "Codable",
       "printedName": "Codable",
-      "declKind": "TypeAlias",
-      "usr": "s:s7Codablea",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
           "name": "ProtocolComposition",
           "printedName": "Decodable & Encodable"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s7Codablea",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "CodingKey",
       "printedName": "CodingKey",
-      "declKind": "Protocol",
-      "usr": "s:s9CodingKeyP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : CustomDebugStringConvertible, Self : CustomStringConvertible>",
-      "conformingProtocols": [
-        "CustomStringConvertible",
-        "CustomDebugStringConvertible"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "stringValue",
           "printedName": "stringValue",
-          "declKind": "Var",
-          "usr": "s:s9CodingKeyP11stringValueSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -6042,11 +6697,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s9CodingKeyP11stringValueSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6054,32 +6704,35 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s9CodingKeyP11stringValueSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : CodingKey>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s9CodingKeyP11stringValueSSvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(stringValue:)",
-          "declKind": "Constructor",
-          "usr": "s:s9CodingKeyP11stringValuexSgSS_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : CodingKey>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -6087,22 +6740,22 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s9CodingKeyP11stringValuexSgSS_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : CodingKey>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "intValue",
           "printedName": "intValue",
-          "declKind": "Var",
-          "usr": "s:s9CodingKeyP8intValueSiSgvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6110,23 +6763,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s9CodingKeyP8intValueSiSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Int?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -6134,34 +6782,38 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s9CodingKeyP8intValueSiSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : CodingKey>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s9CodingKeyP8intValueSiSgvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(intValue:)",
-          "declKind": "Constructor",
-          "usr": "s:s9CodingKeyP8intValuexSgSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : CodingKey>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -6169,19 +6821,17 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s9CodingKeyP8intValuexSgSi_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : CodingKey>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:s9CodingKeyPsE11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -6193,11 +6843,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s9CodingKeyPsE11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6205,18 +6850,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s9CodingKeyPsE11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : CodingKey>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s9CodingKeyPsE11descriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s9CodingKeyPsE16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -6228,11 +6876,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s9CodingKeyPsE16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6240,35 +6883,41 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s9CodingKeyPsE16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : CodingKey>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s9CodingKeyPsE16debugDescriptionSSvp",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s9CodingKeyP",
+      "moduleName": "Swift",
+      "genericSig": "<Self : CustomDebugStringConvertible, Self : CustomStringConvertible>",
+      "conformingProtocols": [
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Encoder",
       "printedName": "Encoder",
-      "declKind": "Protocol",
-      "usr": "s:s7EncoderP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s7EncoderP10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[CodingKey]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6276,23 +6925,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7EncoderP10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Encoder>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -6300,26 +6944,30 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7EncoderP10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Encoder>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s7EncoderP10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "userInfo",
           "printedName": "userInfo",
-          "declKind": "Var",
-          "usr": "s:s7EncoderP8userInfoSDys010CodingUserC3KeyVypGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Dictionary",
               "printedName": "[CodingUserInfoKey : Any]",
-              "usr": "s:SD",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6332,23 +6980,18 @@
                   "name": "ProtocolComposition",
                   "printedName": "Any"
                 }
-              ]
+              ],
+              "usr": "s:SD"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7EncoderP8userInfoSDys010CodingUserC3KeyVypGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Encoder>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Dictionary",
                   "printedName": "[CodingUserInfoKey : Any]",
-                  "usr": "s:SD",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -6361,34 +7004,38 @@
                       "name": "ProtocolComposition",
                       "printedName": "Any"
                     }
-                  ]
+                  ],
+                  "usr": "s:SD"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7EncoderP8userInfoSDys010CodingUserC3KeyVypGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Encoder>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s7EncoderP8userInfoSDys010CodingUserC3KeyVypGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "container",
           "printedName": "container(keyedBy:)",
-          "declKind": "Func",
-          "usr": "s:s7EncoderP9container7keyedBys22KeyedEncodingContainerVyqd__Gqd__m_ts9CodingKeyRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Key where Self : Encoder, Key : CodingKey>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedEncodingContainer",
               "printedName": "KeyedEncodingContainer<Key>",
-              "usr": "s:s22KeyedEncodingContainerV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Key"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedEncodingContainerV"
             },
             {
               "kind": "TypeNominal",
@@ -6402,17 +7049,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7EncoderP9container7keyedBys22KeyedEncodingContainerVyqd__Gqd__m_ts9CodingKeyRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Key where Self : Encoder, Key : CodingKey>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "unkeyedContainer",
           "printedName": "unkeyedContainer()",
-          "declKind": "Func",
-          "usr": "s:s7EncoderP16unkeyedContainers015UnkeyedEncodingC0_pyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encoder>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -6420,17 +7067,17 @@
               "printedName": "UnkeyedEncodingContainer",
               "usr": "s:s24UnkeyedEncodingContainerP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7EncoderP16unkeyedContainers015UnkeyedEncodingC0_pyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Encoder>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "singleValueContainer",
           "printedName": "singleValueContainer()",
-          "declKind": "Func",
-          "usr": "s:s7EncoderP20singleValueContainers06Singlec8EncodingD0_pyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encoder>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -6438,33 +7085,32 @@
               "printedName": "SingleValueEncodingContainer",
               "usr": "s:s28SingleValueEncodingContainerP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7EncoderP20singleValueContainers06Singlec8EncodingD0_pyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Encoder>",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s7EncoderP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "Decoder",
       "printedName": "Decoder",
-      "declKind": "Protocol",
-      "usr": "s:s7DecoderP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s7DecoderP10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[CodingKey]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6472,23 +7118,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7DecoderP10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Decoder>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -6496,26 +7137,30 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7DecoderP10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Decoder>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s7DecoderP10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "userInfo",
           "printedName": "userInfo",
-          "declKind": "Var",
-          "usr": "s:s7DecoderP8userInfoSDys010CodingUserC3KeyVypGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Dictionary",
               "printedName": "[CodingUserInfoKey : Any]",
-              "usr": "s:SD",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6528,23 +7173,18 @@
                   "name": "ProtocolComposition",
                   "printedName": "Any"
                 }
-              ]
+              ],
+              "usr": "s:SD"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7DecoderP8userInfoSDys010CodingUserC3KeyVypGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Decoder>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Dictionary",
                   "printedName": "[CodingUserInfoKey : Any]",
-                  "usr": "s:SD",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -6557,35 +7197,38 @@
                       "name": "ProtocolComposition",
                       "printedName": "Any"
                     }
-                  ]
+                  ],
+                  "usr": "s:SD"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7DecoderP8userInfoSDys010CodingUserC3KeyVypGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Decoder>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s7DecoderP8userInfoSDys010CodingUserC3KeyVypGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "container",
           "printedName": "container(keyedBy:)",
-          "declKind": "Func",
-          "usr": "s:s7DecoderP9container7keyedBys22KeyedDecodingContainerVyqd__Gqd__m_tKs9CodingKeyRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Key where Self : Decoder, Key : CodingKey>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedDecodingContainer",
               "printedName": "KeyedDecodingContainer<Key>",
-              "usr": "s:s22KeyedDecodingContainerV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Key"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedDecodingContainerV"
             },
             {
               "kind": "TypeNominal",
@@ -6599,18 +7242,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7DecoderP9container7keyedBys22KeyedDecodingContainerVyqd__Gqd__m_tKs9CodingKeyRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Key where Self : Decoder, Key : CodingKey>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "unkeyedContainer",
           "printedName": "unkeyedContainer()",
-          "declKind": "Func",
-          "usr": "s:s7DecoderP16unkeyedContainers015UnkeyedDecodingC0_pyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decoder>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6618,18 +7261,18 @@
               "printedName": "UnkeyedDecodingContainer",
               "usr": "s:s24UnkeyedDecodingContainerP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7DecoderP16unkeyedContainers015UnkeyedDecodingC0_pyKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Decoder>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "singleValueContainer",
           "printedName": "singleValueContainer()",
-          "declKind": "Func",
-          "usr": "s:s7DecoderP20singleValueContainers06Singlec8DecodingD0_pyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decoder>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6637,34 +7280,42 @@
               "printedName": "SingleValueDecodingContainer",
               "usr": "s:s28SingleValueDecodingContainerP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7DecoderP20singleValueContainers06Singlec8DecodingD0_pyKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Decoder>",
+          "protocolReq": true,
+          "throwing": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s7DecoderP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "KeyedEncodingContainerProtocol",
       "printedName": "KeyedEncodingContainerProtocol",
-      "declKind": "Protocol",
-      "usr": "s:s30KeyedEncodingContainerProtocolP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self.Key : CodingKey>",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Key",
+          "printedName": "Key",
+          "declKind": "AssociatedType",
+          "usr": "s:s30KeyedEncodingContainerProtocolP3KeyQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s30KeyedEncodingContainerProtocolP10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[CodingKey]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -6672,23 +7323,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s30KeyedEncodingContainerProtocolP10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -6696,23 +7342,25 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s30KeyedEncodingContainerProtocolP10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s30KeyedEncodingContainerProtocolP10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "encodeNil",
           "printedName": "encodeNil(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP9encodeNil6forKeyy0H0Qz_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6724,19 +7372,19 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP9encodeNil6forKeyy0H0Qz_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySb_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6754,19 +7402,19 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySb_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySS_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6784,19 +7432,19 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySS_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySd_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6814,19 +7462,19 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySd_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySf_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6844,19 +7492,19 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySf_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySi_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6874,19 +7522,19 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySi_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys4Int8V_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6904,19 +7552,19 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys4Int8V_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys5Int16V_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6934,19 +7582,19 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys5Int16V_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys5Int32V_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6964,19 +7612,19 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys5Int32V_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys5Int64V_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -6994,19 +7642,19 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys5Int64V_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySu_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7024,19 +7672,19 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyySu_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys5UInt8V_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7054,19 +7702,19 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys5UInt8V_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys6UInt16V_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7084,19 +7732,19 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys6UInt16V_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys6UInt32V_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7114,19 +7762,19 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys6UInt32V_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys6UInt64V_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7144,19 +7792,19 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyys6UInt64V_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyyqd___0G0QztKSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : KeyedEncodingContainerProtocol, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7173,19 +7821,19 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP6encode_6forKeyyqd___0G0QztKSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : KeyedEncodingContainerProtocol, T : Encodable>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeConditional",
           "printedName": "encodeConditional(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP17encodeConditional_6forKeyyqd___0H0QztKRld__CSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : KeyedEncodingContainerProtocol, T : AnyObject, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7202,19 +7850,19 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP17encodeConditional_6forKeyyqd___0H0QztKRld__CSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : KeyedEncodingContainerProtocol, T : AnyObject, T : Encodable>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySbSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7225,7 +7873,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Bool?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7233,26 +7880,27 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySbSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySSSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7263,7 +7911,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "String?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7271,26 +7918,27 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySSSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySdSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7301,7 +7949,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Double?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7309,26 +7956,27 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySdSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySfSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7339,7 +7987,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Float?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7347,26 +7994,27 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySfSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySiSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7377,7 +8025,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7385,26 +8032,27 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySiSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys4Int8VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7415,7 +8063,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7423,26 +8070,27 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys4Int8VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys5Int16VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7453,7 +8101,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7461,26 +8108,27 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys5Int16VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys5Int32VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7491,7 +8139,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7499,26 +8146,27 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys5Int32VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys5Int64VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7529,7 +8177,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7537,26 +8184,27 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys5Int64VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySuSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7567,7 +8215,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7575,26 +8222,27 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyySuSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys5UInt8VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7605,7 +8253,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7613,26 +8260,27 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys5UInt8VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys6UInt16VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7643,7 +8291,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7651,26 +8298,27 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys6UInt16VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys6UInt32VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7681,7 +8329,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7689,26 +8336,27 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys6UInt32VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys6UInt64VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7719,7 +8367,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7727,26 +8374,27 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyys6UInt64VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyyqd__Sg_0I0QztKSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : KeyedEncodingContainerProtocol, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7757,45 +8405,46 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "T?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP15encodeIfPresent_6forKeyyqd__Sg_0I0QztKSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : KeyedEncodingContainerProtocol, T : Encodable>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "nestedContainer",
           "printedName": "nestedContainer(keyedBy:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP06nestedC07keyedBy6forKeys0abC0Vyqd__Gqd__m_0I0Qzts06CodingI0Rd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, NestedKey where Self : KeyedEncodingContainerProtocol, NestedKey : CodingKey>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedEncodingContainer",
               "printedName": "KeyedEncodingContainer<NestedKey>",
-              "usr": "s:s22KeyedEncodingContainerV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "NestedKey"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedEncodingContainerV"
             },
             {
               "kind": "TypeNominal",
@@ -7814,18 +8463,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP06nestedC07keyedBy6forKeys0abC0Vyqd__Gqd__m_0I0Qzts06CodingI0Rd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, NestedKey where Self : KeyedEncodingContainerProtocol, NestedKey : CodingKey>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "nestedUnkeyedContainer",
           "printedName": "nestedUnkeyedContainer(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP013nestedUnkeyedC06forKeys0fbC0_p0H0Qz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7838,18 +8487,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP013nestedUnkeyedC06forKeys0fbC0_p0H0Qz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "superEncoder",
           "printedName": "superEncoder()",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP12superEncoders0F0_pyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7857,18 +8506,18 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP12superEncoders0F0_pyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "superEncoder",
           "printedName": "superEncoder(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolP12superEncoder6forKeys0F0_p0H0Qz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -7881,22 +8530,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolP12superEncoder6forKeys0F0_p0H0Qz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeConditional",
           "printedName": "encodeConditional(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE17encodeConditional_6forKeyyqd___0H0QztKRld__CSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : KeyedEncodingContainerProtocol, T : AnyObject, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -7913,22 +8558,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE17encodeConditional_6forKeyyqd___0H0QztKRld__CSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : KeyedEncodingContainerProtocol, T : AnyObject, T : Encodable>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySbSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -7939,7 +8580,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Bool?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7947,29 +8587,26 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySbSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySSSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -7980,7 +8617,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "String?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -7988,29 +8624,26 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySSSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySdSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8021,7 +8654,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Double?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8029,29 +8661,26 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySdSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySfSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8062,7 +8691,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Float?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8070,29 +8698,26 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySfSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySiSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8103,7 +8728,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8111,29 +8735,26 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySiSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys4Int8VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8144,7 +8765,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8152,29 +8772,26 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys4Int8VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys5Int16VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8185,7 +8802,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8193,29 +8809,26 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys5Int16VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys5Int32VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8226,7 +8839,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8234,29 +8846,26 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys5Int32VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys5Int64VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8267,7 +8876,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8275,29 +8883,26 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys5Int64VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySuSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8308,7 +8913,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8316,29 +8920,26 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyySuSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys5UInt8VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8349,7 +8950,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8357,29 +8957,26 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys5UInt8VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys6UInt16VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8390,7 +8987,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8398,29 +8994,26 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys6UInt16VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys6UInt32VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8431,7 +9024,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8439,29 +9031,26 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys6UInt32VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys6UInt64VSg_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8472,7 +9061,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8480,29 +9068,26 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyys6UInt64VSg_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedEncodingContainerProtocol>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyyqd__Sg_0I0QztKSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : KeyedEncodingContainerProtocol, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8513,107 +9098,93 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "T?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedEncodingContainerProtocolPsE15encodeIfPresent_6forKeyyqd__Sg_0I0QztKSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : KeyedEncodingContainerProtocol, T : Encodable>",
+          "throwing": true,
+          "mutating": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s30KeyedEncodingContainerProtocolP",
+      "moduleName": "Swift",
+      "genericSig": "<Self.Key : CodingKey>"
     },
     {
       "kind": "TypeDecl",
       "name": "KeyedEncodingContainer",
       "printedName": "KeyedEncodingContainer",
-      "declKind": "Struct",
-      "usr": "s:s22KeyedEncodingContainerV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<K where K : CodingKey>",
-      "conformingProtocols": [
-        "KeyedEncodingContainerProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Key",
           "printedName": "Key",
-          "declKind": "TypeAlias",
-          "usr": "s:s22KeyedEncodingContainerV3Keya",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "K"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s22KeyedEncodingContainerV3Keya",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s22KeyedEncodingContainerVyAByxGqd__c3KeyQyd__Rszs0abC8ProtocolRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, Container where K == Container.Key, Container : KeyedEncodingContainerProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedEncodingContainer",
               "printedName": "KeyedEncodingContainer<K>",
-              "usr": "s:s22KeyedEncodingContainerV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "K"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedEncodingContainerV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Container"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s22KeyedEncodingContainerVyAByxGqd__c3KeyQyd__Rszs0abC8ProtocolRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<K, Container where K == Container.Key, Container : KeyedEncodingContainerProtocol>"
         },
         {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s22KeyedEncodingContainerV10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[CodingKey]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -8621,23 +9192,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s22KeyedEncodingContainerV10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<K where K : CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -8645,26 +9211,24 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s22KeyedEncodingContainerV10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<K where K : CodingKey>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s22KeyedEncodingContainerV10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "encodeNil",
           "printedName": "encodeNil(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV9encodeNil6forKeyyx_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8683,22 +9247,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV9encodeNil6forKeyyx_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySb_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8723,22 +9283,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySb_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySS_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8763,22 +9319,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySS_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySd_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8803,22 +9355,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySd_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySf_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8843,22 +9391,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySf_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySi_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8883,22 +9427,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySi_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys4Int8V_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8923,22 +9463,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys4Int8V_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys5Int16V_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -8963,22 +9499,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys5Int16V_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys5Int32V_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9003,22 +9535,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys5Int32V_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys5Int64V_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9043,22 +9571,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys5Int64V_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySu_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9083,22 +9607,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyySu_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys5UInt8V_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9123,22 +9643,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys5UInt8V_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys6UInt16V_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9163,22 +9679,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys6UInt16V_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys6UInt32V_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9203,22 +9715,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys6UInt32V_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys6UInt64V_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9243,22 +9751,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyys6UInt64V_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyyqd___xtKSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, T where K : CodingKey, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9282,22 +9786,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV6encode_6forKeyyqd___xtKSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<K, T where K : CodingKey, T : Encodable>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeConditional",
           "printedName": "encodeConditional(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV17encodeConditional_6forKeyyqd___xtKRld__CSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, T where K : CodingKey, T : AnyObject, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9321,22 +9821,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV17encodeConditional_6forKeyyqd___xtKRld__CSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<K, T where K : CodingKey, T : AnyObject, T : Encodable>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySbSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9347,7 +9843,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Bool?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9355,7 +9850,8 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -9369,22 +9865,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySbSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySSSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9395,7 +9887,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "String?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9403,7 +9894,8 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -9417,22 +9909,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySSSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySdSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9443,7 +9931,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Double?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9451,7 +9938,8 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -9465,22 +9953,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySdSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySfSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9491,7 +9975,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Float?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9499,7 +9982,8 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -9513,22 +9997,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySfSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySiSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9539,7 +10019,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9547,7 +10026,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -9561,22 +10041,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySiSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys4Int8VSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9587,7 +10063,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9595,7 +10070,8 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -9609,22 +10085,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys4Int8VSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys5Int16VSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9635,7 +10107,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9643,7 +10114,8 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -9657,22 +10129,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys5Int16VSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys5Int32VSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9683,7 +10151,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9691,7 +10158,8 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -9705,22 +10173,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys5Int32VSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys5Int64VSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9731,7 +10195,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9739,7 +10202,8 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -9753,22 +10217,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys5Int64VSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySuSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9779,7 +10239,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9787,7 +10246,8 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -9801,22 +10261,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyySuSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys5UInt8VSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9827,7 +10283,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9835,7 +10290,8 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -9849,22 +10305,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys5UInt8VSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys6UInt16VSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9875,7 +10327,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9883,7 +10334,8 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -9897,22 +10349,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys6UInt16VSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys6UInt32VSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9923,7 +10371,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9931,7 +10378,8 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -9945,22 +10393,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys6UInt32VSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys6UInt64VSg_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -9971,7 +10415,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -9979,7 +10422,8 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -9993,22 +10437,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyys6UInt64VSg_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeIfPresent",
           "printedName": "encodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyyqd__Sg_xtKSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, T where K : CodingKey, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -10019,14 +10459,14 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "T?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -10040,34 +10480,31 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV15encodeIfPresent_6forKeyyqd__Sg_xtKSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<K, T where K : CodingKey, T : Encodable>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "nestedContainer",
           "printedName": "nestedContainer(keyedBy:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV06nestedC07keyedBy6forKeyAByqd__Gqd__m_xts06CodingH0Rd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, NestedKey where K : CodingKey, NestedKey : CodingKey>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedEncodingContainer",
               "printedName": "KeyedEncodingContainer<NestedKey>",
-              "usr": "s:s22KeyedEncodingContainerV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "NestedKey"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedEncodingContainerV"
             },
             {
               "kind": "TypeNominal",
@@ -10093,21 +10530,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV06nestedC07keyedBy6forKeyAByqd__Gqd__m_xts06CodingH0Rd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<K, NestedKey where K : CodingKey, NestedKey : CodingKey>",
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "nestedUnkeyedContainer",
           "printedName": "nestedUnkeyedContainer(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV013nestedUnkeyedC06forKeys0ebC0_px_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -10127,21 +10560,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV013nestedUnkeyedC06forKeys0ebC0_px_tF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "superEncoder",
           "printedName": "superEncoder()",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV12superEncoders0E0_pyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -10149,21 +10578,17 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV12superEncoders0E0_pyF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "superEncoder",
           "printedName": "superEncoder(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedEncodingContainerV12superEncoder6forKeys0E0_px_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -10183,34 +10608,45 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedEncodingContainerV12superEncoder6forKeys0E0_px_tF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "mutating": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s22KeyedEncodingContainerV",
+      "moduleName": "Swift",
+      "genericSig": "<K where K : CodingKey>",
+      "conformingProtocols": [
+        "KeyedEncodingContainerProtocol"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "KeyedDecodingContainerProtocol",
       "printedName": "KeyedDecodingContainerProtocol",
-      "declKind": "Protocol",
-      "usr": "s:s30KeyedDecodingContainerProtocolP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self.Key : CodingKey>",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Key",
+          "printedName": "Key",
+          "declKind": "AssociatedType",
+          "usr": "s:s30KeyedDecodingContainerProtocolP3KeyQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s30KeyedDecodingContainerProtocolP10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[CodingKey]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -10218,23 +10654,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s30KeyedDecodingContainerProtocolP10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -10242,70 +10673,73 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s30KeyedDecodingContainerProtocolP10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s30KeyedDecodingContainerProtocolP10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "allKeys",
           "printedName": "allKeys",
-          "declKind": "Var",
-          "usr": "s:s30KeyedDecodingContainerProtocolP7allKeysSay3KeyQzGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Self.Key]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Key"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s30KeyedDecodingContainerProtocolP7allKeysSay3KeyQzGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[Self.Key]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Self.Key"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s30KeyedDecodingContainerProtocolP7allKeysSay3KeyQzGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s30KeyedDecodingContainerProtocolP7allKeysSay3KeyQzGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP8containsySb3KeyQzF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -10318,18 +10752,17 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP8containsySb3KeyQzF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "decodeNil",
           "printedName": "decodeNil(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP9decodeNil6forKeySb0H0Qz_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10342,18 +10775,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP9decodeNil6forKeySb0H0Qz_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2bm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10379,18 +10812,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2bm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2Sm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10416,18 +10849,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2Sm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2dm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10453,18 +10886,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2dm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2fm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10490,18 +10923,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2fm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2im_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10527,18 +10960,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2im_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys4Int8VAFm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10564,18 +10997,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys4Int8VAFm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys5Int16VAFm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10601,18 +11034,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys5Int16VAFm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys5Int32VAFm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10638,18 +11071,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys5Int32VAFm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys5Int64VAFm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10675,18 +11108,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys5Int64VAFm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2um_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10712,18 +11145,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyS2um_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys5UInt8VAFm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10749,18 +11182,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys5UInt8VAFm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys6UInt16VAFm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10786,18 +11219,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys6UInt16VAFm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys6UInt32VAFm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10823,18 +11256,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys6UInt32VAFm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys6UInt64VAFm_0G0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10860,18 +11293,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeys6UInt64VAFm_0G0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyqd__qd__m_0G0QztKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : KeyedDecodingContainerProtocol, T : Decodable>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -10895,24 +11328,23 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP6decode_6forKeyqd__qd__m_0G0QztKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : KeyedDecodingContainerProtocol, T : Decodable>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySbSgSbm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Bool?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -10920,7 +11352,8 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -10940,24 +11373,23 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySbSgSbm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySSSgSSm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "String?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -10965,7 +11397,8 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -10985,24 +11418,23 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySSSgSSm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySdSgSdm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Double?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11010,7 +11442,8 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11030,24 +11463,23 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySdSgSdm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySfSgSfm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Float?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11055,7 +11487,8 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11075,24 +11508,23 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySfSgSfm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySiSgSim_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11100,7 +11532,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11120,24 +11553,23 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySiSgSim_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys4Int8VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11145,7 +11577,8 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11165,24 +11598,23 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys4Int8VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys5Int16VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11190,7 +11622,8 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11210,24 +11643,23 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys5Int16VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys5Int32VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11235,7 +11667,8 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11255,24 +11688,23 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys5Int32VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys5Int64VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11280,7 +11712,8 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11300,24 +11733,23 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys5Int64VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySuSgSum_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11325,7 +11757,8 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11345,24 +11778,23 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeySuSgSum_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys5UInt8VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11370,7 +11802,8 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11390,24 +11823,23 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys5UInt8VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys6UInt16VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11415,7 +11847,8 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11435,24 +11868,23 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys6UInt16VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys6UInt32VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11460,7 +11892,8 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11480,24 +11913,23 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys6UInt32VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys6UInt64VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11505,7 +11937,8 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11525,31 +11958,31 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeys6UInt64VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeyqd__Sgqd__m_0I0QztKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : KeyedDecodingContainerProtocol, T : Decodable>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "T?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11568,31 +12001,31 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP15decodeIfPresent_6forKeyqd__Sgqd__m_0I0QztKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : KeyedDecodingContainerProtocol, T : Decodable>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "nestedContainer",
           "printedName": "nestedContainer(keyedBy:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP06nestedC07keyedBy6forKeys0abC0Vyqd__Gqd__m_0I0QztKs06CodingI0Rd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, NestedKey where Self : KeyedDecodingContainerProtocol, NestedKey : CodingKey>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedDecodingContainer",
               "printedName": "KeyedDecodingContainer<NestedKey>",
-              "usr": "s:s22KeyedDecodingContainerV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "NestedKey"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedDecodingContainerV"
             },
             {
               "kind": "TypeNominal",
@@ -11611,18 +12044,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP06nestedC07keyedBy6forKeys0abC0Vyqd__Gqd__m_0I0QztKs06CodingI0Rd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, NestedKey where Self : KeyedDecodingContainerProtocol, NestedKey : CodingKey>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "nestedUnkeyedContainer",
           "printedName": "nestedUnkeyedContainer(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP013nestedUnkeyedC06forKeys0fbC0_p0H0Qz_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -11635,18 +12068,18 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP013nestedUnkeyedC06forKeys0fbC0_p0H0Qz_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "superDecoder",
           "printedName": "superDecoder()",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP12superDecoders0F0_pyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -11654,18 +12087,18 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP12superDecoders0F0_pyKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "superDecoder",
           "printedName": "superDecoder(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolP12superDecoder6forKeys0F0_p0H0Qz_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -11678,27 +12111,23 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolP12superDecoder6forKeys0F0_p0H0Qz_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySbSgSbm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Bool?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11706,7 +12135,8 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11726,27 +12156,22 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySbSgSbm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySSSgSSm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "String?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11754,7 +12179,8 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11774,27 +12200,22 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySSSgSSm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySdSgSdm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Double?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11802,7 +12223,8 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11822,27 +12244,22 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySdSgSdm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySfSgSfm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Float?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11850,7 +12267,8 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11870,27 +12288,22 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySfSgSfm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySiSgSim_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11898,7 +12311,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11918,27 +12332,22 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySiSgSim_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys4Int8VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11946,7 +12355,8 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -11966,27 +12376,22 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys4Int8VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys5Int16VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -11994,7 +12399,8 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -12014,27 +12420,22 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys5Int16VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys5Int32VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -12042,7 +12443,8 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -12062,27 +12464,22 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys5Int32VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys5Int64VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -12090,7 +12487,8 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -12110,27 +12508,22 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys5Int64VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySuSgSum_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -12138,7 +12531,8 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -12158,27 +12552,22 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeySuSgSum_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys5UInt8VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -12186,7 +12575,8 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -12206,27 +12596,22 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys5UInt8VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys6UInt16VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -12234,7 +12619,8 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -12254,27 +12640,22 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys6UInt16VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys6UInt32VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -12282,7 +12663,8 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -12302,27 +12684,22 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys6UInt32VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys6UInt64VSgAFm_0I0QztKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -12330,7 +12707,8 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -12350,34 +12728,30 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeys6UInt64VSgAFm_0I0QztKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : KeyedDecodingContainerProtocol>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeyqd__Sgqd__m_0I0QztKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : KeyedDecodingContainerProtocol, T : Decodable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "T?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -12396,93 +12770,78 @@
               "name": "DependentMember",
               "printedName": "Self.Key"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s30KeyedDecodingContainerProtocolPsE15decodeIfPresent_6forKeyqd__Sgqd__m_0I0QztKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : KeyedDecodingContainerProtocol, T : Decodable>",
+          "throwing": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s30KeyedDecodingContainerProtocolP",
+      "moduleName": "Swift",
+      "genericSig": "<Self.Key : CodingKey>"
     },
     {
       "kind": "TypeDecl",
       "name": "KeyedDecodingContainer",
       "printedName": "KeyedDecodingContainer",
-      "declKind": "Struct",
-      "usr": "s:s22KeyedDecodingContainerV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<K where K : CodingKey>",
-      "conformingProtocols": [
-        "KeyedDecodingContainerProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Key",
           "printedName": "Key",
-          "declKind": "TypeAlias",
-          "usr": "s:s22KeyedDecodingContainerV3Keya",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "K"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s22KeyedDecodingContainerV3Keya",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s22KeyedDecodingContainerVyAByxGqd__c3KeyQyd__Rszs0abC8ProtocolRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, Container where K == Container.Key, Container : KeyedDecodingContainerProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedDecodingContainer",
               "printedName": "KeyedDecodingContainer<K>",
-              "usr": "s:s22KeyedDecodingContainerV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "K"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedDecodingContainerV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Container"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s22KeyedDecodingContainerVyAByxGqd__c3KeyQyd__Rszs0abC8ProtocolRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<K, Container where K == Container.Key, Container : KeyedDecodingContainerProtocol>"
         },
         {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s22KeyedDecodingContainerV10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[CodingKey]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -12490,23 +12849,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s22KeyedDecodingContainerV10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<K where K : CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -12514,76 +12868,71 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s22KeyedDecodingContainerV10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<K where K : CodingKey>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s22KeyedDecodingContainerV10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "allKeys",
           "printedName": "allKeys",
-          "declKind": "Var",
-          "usr": "s:s22KeyedDecodingContainerV7allKeysSayxGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[K]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "K"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s22KeyedDecodingContainerV7allKeysSayxGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<K where K : CodingKey>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[K]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "K"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s22KeyedDecodingContainerV7allKeysSayxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<K where K : CodingKey>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s22KeyedDecodingContainerV7allKeysSayxGvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV8containsySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12603,21 +12952,16 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV8containsySbxF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>"
         },
         {
           "kind": "Function",
           "name": "decodeNil",
           "printedName": "decodeNil(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV9decodeNil6forKeySbx_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12637,21 +12981,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV9decodeNil6forKeySbx_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2bm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12684,21 +13024,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2bm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2Sm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12731,21 +13067,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2Sm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2dm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12778,21 +13110,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2dm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2fm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12825,21 +13153,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2fm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2im_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12872,21 +13196,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2im_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys4Int8VAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12919,21 +13239,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys4Int8VAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys5Int16VAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -12966,21 +13282,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys5Int16VAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys5Int32VAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -13013,21 +13325,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys5Int32VAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys5Int64VAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -13060,21 +13368,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys5Int64VAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2um_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -13107,21 +13411,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyS2um_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys5UInt8VAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -13154,21 +13454,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys5UInt8VAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys6UInt16VAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -13201,21 +13497,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys6UInt16VAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys6UInt32VAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -13248,21 +13540,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys6UInt32VAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys6UInt64VAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -13295,21 +13583,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeys6UInt64VAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyqd__qd__m_xtKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, T where K : CodingKey, T : Decodable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -13340,27 +13624,22 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV6decode_6forKeyqd__qd__m_xtKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<K, T where K : CodingKey, T : Decodable>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySbSgSbm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Bool?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13368,7 +13647,8 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13395,27 +13675,22 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySbSgSbm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySSSgSSm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "String?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13423,7 +13698,8 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13450,27 +13726,22 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySSSgSSm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySdSgSdm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Double?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13478,7 +13749,8 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13505,27 +13777,22 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySdSgSdm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySfSgSfm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Float?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13533,7 +13800,8 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13560,27 +13828,22 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySfSgSfm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySiSgSim_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13588,7 +13851,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13615,27 +13879,22 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySiSgSim_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys4Int8VSgAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13643,7 +13902,8 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13670,27 +13930,22 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys4Int8VSgAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys5Int16VSgAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13698,7 +13953,8 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13725,27 +13981,22 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys5Int16VSgAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys5Int32VSgAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13753,7 +14004,8 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13780,27 +14032,22 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys5Int32VSgAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys5Int64VSgAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13808,7 +14055,8 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13835,27 +14083,22 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys5Int64VSgAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySuSgSum_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13863,7 +14106,8 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13890,27 +14134,22 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeySuSgSum_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys5UInt8VSgAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13918,7 +14157,8 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -13945,27 +14185,22 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys5UInt8VSgAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys6UInt16VSgAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -13973,7 +14208,8 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -14000,27 +14236,22 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys6UInt16VSgAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys6UInt32VSgAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -14028,7 +14259,8 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -14055,27 +14287,22 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys6UInt32VSgAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys6UInt64VSgAFm_xtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -14083,7 +14310,8 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -14110,34 +14338,30 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeys6UInt64VSgAFm_xtKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeyqd__Sgqd__m_xtKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, T where K : CodingKey, T : Decodable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "T?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -14163,34 +14387,30 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV15decodeIfPresent_6forKeyqd__Sgqd__m_xtKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<K, T where K : CodingKey, T : Decodable>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "nestedContainer",
           "printedName": "nestedContainer(keyedBy:forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV06nestedC07keyedBy6forKeyAByqd__Gqd__m_xtKs06CodingH0Rd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K, NestedKey where K : CodingKey, NestedKey : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedDecodingContainer",
               "printedName": "KeyedDecodingContainer<NestedKey>",
-              "usr": "s:s22KeyedDecodingContainerV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "NestedKey"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedDecodingContainerV"
             },
             {
               "kind": "TypeNominal",
@@ -14216,21 +14436,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV06nestedC07keyedBy6forKeyAByqd__Gqd__m_xtKs06CodingH0Rd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<K, NestedKey where K : CodingKey, NestedKey : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "nestedUnkeyedContainer",
           "printedName": "nestedUnkeyedContainer(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV013nestedUnkeyedC06forKeys0ebC0_px_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -14250,21 +14466,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV013nestedUnkeyedC06forKeys0ebC0_px_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "superDecoder",
           "printedName": "superDecoder()",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV12superDecoders0E0_pyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -14272,21 +14484,17 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV12superDecoders0E0_pyKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "superDecoder",
           "printedName": "superDecoder(forKey:)",
-          "declKind": "Func",
-          "usr": "s:s22KeyedDecodingContainerV12superDecoder6forKeys0E0_px_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<K where K : CodingKey>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -14306,33 +14514,36 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s22KeyedDecodingContainerV12superDecoder6forKeys0E0_px_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<K where K : CodingKey>",
+          "throwing": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s22KeyedDecodingContainerV",
+      "moduleName": "Swift",
+      "genericSig": "<K where K : CodingKey>",
+      "conformingProtocols": [
+        "KeyedDecodingContainerProtocol"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnkeyedEncodingContainer",
       "printedName": "UnkeyedEncodingContainer",
-      "declKind": "Protocol",
-      "usr": "s:s24UnkeyedEncodingContainerP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s24UnkeyedEncodingContainerP10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[CodingKey]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -14340,23 +14551,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s24UnkeyedEncodingContainerP10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -14364,20 +14570,25 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s24UnkeyedEncodingContainerP10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : UnkeyedEncodingContainer>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s24UnkeyedEncodingContainerP10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s24UnkeyedEncodingContainerP5countSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14389,11 +14600,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s24UnkeyedEncodingContainerP5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -14401,40 +14607,41 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s24UnkeyedEncodingContainerP5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : UnkeyedEncodingContainer>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s24UnkeyedEncodingContainerP5countSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "encodeNil",
           "printedName": "encodeNil()",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP9encodeNilyyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP9encodeNilyyKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySbKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14447,19 +14654,19 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySbKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySSKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14472,19 +14679,19 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySSKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySdKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14497,19 +14704,19 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySdKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySfKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14522,19 +14729,19 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySfKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySiKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14547,19 +14754,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySiKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys4Int8VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14572,19 +14779,19 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys4Int8VKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys5Int16VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14597,19 +14804,19 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys5Int16VKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys5Int32VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14622,19 +14829,19 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys5Int32VKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys5Int64VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14647,19 +14854,19 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys5Int64VKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySuKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14672,19 +14879,19 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyySuKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys5UInt8VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14697,19 +14904,19 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys5UInt8VKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys6UInt16VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14722,19 +14929,19 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys6UInt16VKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys6UInt32VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14747,19 +14954,19 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys6UInt32VKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys6UInt64VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14772,19 +14979,19 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyys6UInt64VKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encodeyyqd__KSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -14796,19 +15003,43 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encodeyyqd__KSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Encodable>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeConditional",
           "printedName": "encodeConditional(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "T"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP17encodeConditionalyyqd__KRld__CSERd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : AnyObject, T : Encodable>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14820,19 +15051,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__Sb7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Bool>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14844,19 +15075,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__SS7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == String>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14868,19 +15099,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__Sd7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Double>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14892,19 +15123,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__Sf7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Float>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14916,19 +15147,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__Si7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14940,19 +15171,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__s4Int8V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int8>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14964,19 +15195,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__s5Int16V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int16>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -14988,19 +15219,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__s5Int32V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int32>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15012,19 +15243,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__s5Int64V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int64>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15036,19 +15267,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__Su7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15060,19 +15291,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__s5UInt8V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt8>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15084,19 +15315,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__s6UInt16V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt16>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15108,19 +15339,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__s6UInt32V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt32>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15132,43 +15363,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__s6UInt64V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt64>",
+          "protocolReq": true,
           "throwing": true,
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__SE7ElementRpd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element : Encodable>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -15180,31 +15387,32 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP6encode10contentsOfyqd___tKSTRd__SE7ElementRpd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element : Encodable>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "nestedContainer",
           "printedName": "nestedContainer(keyedBy:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP06nestedC07keyedBys05KeyedbC0Vyqd__Gqd__m_ts9CodingKeyRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, NestedKey where Self : UnkeyedEncodingContainer, NestedKey : CodingKey>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedEncodingContainer",
               "printedName": "KeyedEncodingContainer<NestedKey>",
-              "usr": "s:s22KeyedEncodingContainerV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "NestedKey"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedEncodingContainerV"
             },
             {
               "kind": "TypeNominal",
@@ -15218,18 +15426,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP06nestedC07keyedBys05KeyedbC0Vyqd__Gqd__m_ts9CodingKeyRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, NestedKey where Self : UnkeyedEncodingContainer, NestedKey : CodingKey>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "nestedUnkeyedContainer",
           "printedName": "nestedUnkeyedContainer()",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP06nestedaC0sAA_pyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -15237,18 +15445,18 @@
               "printedName": "UnkeyedEncodingContainer",
               "usr": "s:s24UnkeyedEncodingContainerP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP06nestedaC0sAA_pyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "superEncoder",
           "printedName": "superEncoder()",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerP12superEncoders0E0_pyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -15256,22 +15464,41 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerP12superEncoders0E0_pyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedEncodingContainer>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encodeConditional",
           "printedName": "encodeConditional(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "T"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE17encodeConditionalyyqd__KRld__CSERd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : AnyObject, T : Encodable>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15283,22 +15510,18 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__Sb7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Bool>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15310,22 +15533,18 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__SS7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == String>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15337,22 +15556,18 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__Sd7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Double>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15364,22 +15579,18 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__Sf7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Float>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15391,22 +15602,18 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__Si7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15418,22 +15625,18 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__s4Int8V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int8>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15445,22 +15648,18 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__s5Int16V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int16>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15472,22 +15671,18 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__s5Int32V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int32>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15499,22 +15694,18 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__s5Int64V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == Int64>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15526,22 +15717,18 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__Su7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15553,22 +15740,18 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__s5UInt8V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt8>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15580,22 +15763,18 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__s6UInt16V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt16>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15607,22 +15786,18 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__s6UInt32V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt32>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "encode",
+          "printedName": "encode(contentsOf:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15634,49 +15809,18 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "encode",
-          "printedName": "encode(contentsOf:)",
+          ],
           "declKind": "Func",
           "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__s6UInt64V7ElementRtd__lF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element == UInt64>",
           "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__SE7ElementRpd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element : Encodable>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -15688,33 +15832,33 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedEncodingContainerPsE6encode10contentsOfyqd___tKSTRd__SE7ElementRpd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : UnkeyedEncodingContainer, T : Sequence, T.Element : Encodable>",
+          "throwing": true,
+          "mutating": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s24UnkeyedEncodingContainerP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "UnkeyedDecodingContainer",
       "printedName": "UnkeyedDecodingContainer",
-      "declKind": "Protocol",
-      "usr": "s:s24UnkeyedDecodingContainerP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s24UnkeyedDecodingContainerP10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[CodingKey]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -15722,23 +15866,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s24UnkeyedDecodingContainerP10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -15746,26 +15885,30 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s24UnkeyedDecodingContainerP10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : UnkeyedDecodingContainer>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s24UnkeyedDecodingContainerP10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s24UnkeyedDecodingContainerP5countSiSgvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -15773,23 +15916,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s24UnkeyedDecodingContainerP5countSiSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Int?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -15797,20 +15935,25 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s24UnkeyedDecodingContainerP5countSiSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : UnkeyedDecodingContainer>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s24UnkeyedDecodingContainerP5countSiSgvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "isAtEnd",
           "printedName": "isAtEnd",
-          "declKind": "Var",
-          "usr": "s:s24UnkeyedDecodingContainerP7isAtEndSbvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15822,11 +15965,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s24UnkeyedDecodingContainerP7isAtEndSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -15834,18 +15972,22 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s24UnkeyedDecodingContainerP7isAtEndSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : UnkeyedDecodingContainer>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s24UnkeyedDecodingContainerP7isAtEndSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "currentIndex",
           "printedName": "currentIndex",
-          "declKind": "Var",
-          "usr": "s:s24UnkeyedDecodingContainerP12currentIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -15857,11 +15999,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s24UnkeyedDecodingContainerP12currentIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -15869,21 +16006,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s24UnkeyedDecodingContainerP12currentIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : UnkeyedDecodingContainer>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s24UnkeyedDecodingContainerP12currentIndexSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "decodeNil",
           "printedName": "decodeNil()",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP9decodeNilSbyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -15891,19 +16029,19 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP9decodeNilSbyKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2bmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -15924,19 +16062,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2bmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2SmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -15957,19 +16095,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2SmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2dmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -15990,19 +16128,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2dmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2fmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16023,19 +16161,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2fmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2imKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16056,19 +16194,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2imKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeys4Int8VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16089,19 +16227,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeys4Int8VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeys5Int16VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16122,19 +16260,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeys5Int16VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeys5Int32VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16155,19 +16293,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeys5Int32VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeys5Int64VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16188,19 +16326,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeys5Int64VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2umKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16221,19 +16359,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeyS2umKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeys5UInt8VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16254,19 +16392,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeys5UInt8VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeys6UInt16VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16287,19 +16425,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeys6UInt16VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeys6UInt32VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16320,19 +16458,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeys6UInt32VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeys6UInt64VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16353,19 +16491,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeys6UInt64VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP6decodeyqd__qd__mKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedDecodingContainer, T : Decodable>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -16384,25 +16522,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP6decodeyqd__qd__mKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : UnkeyedDecodingContainer, T : Decodable>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySbSgSbmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Bool?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16410,7 +16547,8 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16425,25 +16563,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySbSgSbmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySSSgSSmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "String?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16451,7 +16588,8 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16466,25 +16604,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySSSgSSmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySdSgSdmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Double?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16492,7 +16629,8 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16507,25 +16645,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySdSgSdmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySfSgSfmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Float?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16533,7 +16670,8 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16548,25 +16686,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySfSgSfmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySiSgSimKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16574,7 +16711,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16589,25 +16727,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySiSgSimKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys4Int8VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16615,7 +16752,8 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16630,25 +16768,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys4Int8VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys5Int16VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16656,7 +16793,8 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16671,25 +16809,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys5Int16VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys5Int32VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16697,7 +16834,8 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16712,25 +16850,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys5Int32VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys5Int64VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16738,7 +16875,8 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16753,25 +16891,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys5Int64VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySuSgSumKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16779,7 +16916,8 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16794,25 +16932,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentySuSgSumKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys5UInt8VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16820,7 +16957,8 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16835,25 +16973,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys5UInt8VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys6UInt16VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16861,7 +16998,8 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16876,25 +17014,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys6UInt16VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys6UInt32VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16902,7 +17039,8 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16917,25 +17055,24 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys6UInt32VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys6UInt64VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -16943,7 +17080,8 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16958,32 +17096,32 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentys6UInt64VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentyqd__Sgqd__mKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedDecodingContainer, T : Decodable>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "T?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -16997,32 +17135,32 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP15decodeIfPresentyqd__Sgqd__mKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : UnkeyedDecodingContainer, T : Decodable>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "nestedContainer",
           "printedName": "nestedContainer(keyedBy:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP06nestedC07keyedBys05KeyedbC0Vyqd__Gqd__m_tKs9CodingKeyRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, NestedKey where Self : UnkeyedDecodingContainer, NestedKey : CodingKey>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyedDecodingContainer",
               "printedName": "KeyedDecodingContainer<NestedKey>",
-              "usr": "s:s22KeyedDecodingContainerV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "NestedKey"
                 }
-              ]
+              ],
+              "usr": "s:s22KeyedDecodingContainerV"
             },
             {
               "kind": "TypeNominal",
@@ -17036,19 +17174,19 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP06nestedC07keyedBys05KeyedbC0Vyqd__Gqd__m_tKs9CodingKeyRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, NestedKey where Self : UnkeyedDecodingContainer, NestedKey : CodingKey>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "nestedUnkeyedContainer",
           "printedName": "nestedUnkeyedContainer()",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP06nestedaC0sAA_pyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17056,19 +17194,19 @@
               "printedName": "UnkeyedDecodingContainer",
               "usr": "s:s24UnkeyedDecodingContainerP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP06nestedaC0sAA_pyKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "superDecoder",
           "printedName": "superDecoder()",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerP12superDecoders0E0_pyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17076,28 +17214,24 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerP12superDecoders0E0_pyKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySbSgSbmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Bool?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17105,7 +17239,8 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17120,28 +17255,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySbSgSbmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySSSgSSmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "String?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17149,7 +17279,8 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17164,28 +17295,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySSSgSSmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySdSgSdmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Double?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17193,7 +17319,8 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17208,28 +17335,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySdSgSdmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySfSgSfmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Float?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17237,7 +17359,8 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17252,28 +17375,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySfSgSfmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySiSgSimKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17281,7 +17399,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17296,28 +17415,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySiSgSimKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys4Int8VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17325,7 +17439,8 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17340,28 +17455,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys4Int8VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys5Int16VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17369,7 +17479,8 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17384,28 +17495,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys5Int16VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys5Int32VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17413,7 +17519,8 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17428,28 +17535,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys5Int32VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys5Int64VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17457,7 +17559,8 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17472,28 +17575,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys5Int64VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySuSgSumKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17501,7 +17599,8 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17516,28 +17615,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentySuSgSumKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys5UInt8VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17545,7 +17639,8 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17560,28 +17655,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys5UInt8VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys6UInt16VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17589,7 +17679,8 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17604,28 +17695,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys6UInt16VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys6UInt32VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17633,7 +17719,8 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17648,28 +17735,23 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys6UInt32VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys6UInt64VSgAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17677,7 +17759,8 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17692,35 +17775,31 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentys6UInt64VSgAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnkeyedDecodingContainer>",
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "decodeIfPresent",
           "printedName": "decodeIfPresent(_:)",
-          "declKind": "Func",
-          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentyqd__Sgqd__mKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : UnkeyedDecodingContainer, T : Decodable>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "T?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -17734,33 +17813,33 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s24UnkeyedDecodingContainerPsE15decodeIfPresentyqd__Sgqd__mKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : UnkeyedDecodingContainer, T : Decodable>",
+          "throwing": true,
+          "mutating": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s24UnkeyedDecodingContainerP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "SingleValueEncodingContainer",
       "printedName": "SingleValueEncodingContainer",
-      "declKind": "Protocol",
-      "usr": "s:s28SingleValueEncodingContainerP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s28SingleValueEncodingContainerP10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[CodingKey]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -17768,23 +17847,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s28SingleValueEncodingContainerP10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : SingleValueEncodingContainer>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -17792,42 +17866,44 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s28SingleValueEncodingContainerP10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : SingleValueEncodingContainer>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s28SingleValueEncodingContainerP10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "encodeNil",
           "printedName": "encodeNil()",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP9encodeNilyyKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP9encodeNilyyKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyySbKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17840,19 +17916,19 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyySbKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyySSKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17865,19 +17941,19 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyySSKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyySdKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17890,19 +17966,19 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyySdKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyySfKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17915,19 +17991,19 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyySfKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyySiKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17940,19 +18016,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyySiKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyys4Int8VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17965,19 +18041,19 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyys4Int8VKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyys5Int16VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -17990,19 +18066,19 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyys5Int16VKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyys5Int32VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18015,19 +18091,19 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyys5Int32VKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyys5Int64VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18040,19 +18116,19 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyys5Int64VKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyySuKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18065,19 +18141,19 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyySuKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyys5UInt8VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18090,19 +18166,19 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyys5UInt8VKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyys6UInt16VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18115,19 +18191,19 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyys6UInt16VKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyys6UInt32VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18140,19 +18216,19 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyys6UInt32VKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyys6UInt64VKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18165,19 +18241,19 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyys6UInt64VKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueEncodingContainer>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueEncodingContainerP6encodeyyqd__KSERd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : SingleValueEncodingContainer, T : Encodable>",
-          "throwing": true,
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18189,33 +18265,34 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueEncodingContainerP6encodeyyqd__KSERd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : SingleValueEncodingContainer, T : Encodable>",
+          "protocolReq": true,
+          "throwing": true,
+          "mutating": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s28SingleValueEncodingContainerP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "SingleValueDecodingContainer",
       "printedName": "SingleValueDecodingContainer",
-      "declKind": "Protocol",
-      "usr": "s:s28SingleValueDecodingContainerP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "codingPath",
           "printedName": "codingPath",
-          "declKind": "Var",
-          "usr": "s:s28SingleValueDecodingContainerP10codingPathSays9CodingKey_pGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[CodingKey]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -18223,23 +18300,18 @@
                   "printedName": "CodingKey",
                   "usr": "s:s9CodingKeyP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s28SingleValueDecodingContainerP10codingPathSays9CodingKey_pGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : SingleValueDecodingContainer>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -18247,21 +18319,25 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s28SingleValueDecodingContainerP10codingPathSays9CodingKey_pGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : SingleValueDecodingContainer>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s28SingleValueDecodingContainerP10codingPathSays9CodingKey_pGvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "decodeNil",
           "printedName": "decodeNil()",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP9decodeNilSbyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -18269,18 +18345,17 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP9decodeNilSbyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2bmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18301,18 +18376,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2bmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2SmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18333,18 +18408,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2SmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2dmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18365,18 +18440,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2dmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2fmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18397,18 +18472,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2fmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2imKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18429,18 +18504,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2imKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeys4Int8VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18461,18 +18536,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeys4Int8VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeys5Int16VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18493,18 +18568,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeys5Int16VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeys5Int32VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18525,18 +18600,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeys5Int32VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeys5Int64VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18557,18 +18632,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeys5Int64VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2umKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18589,18 +18664,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeyS2umKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeys5UInt8VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18621,18 +18696,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeys5UInt8VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeys6UInt16VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18653,18 +18728,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeys6UInt16VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeys6UInt32VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18685,18 +18760,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeys6UInt32VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeys6UInt64VAEmKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18717,18 +18792,18 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeys6UInt64VAEmKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SingleValueDecodingContainer>",
+          "protocolReq": true,
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s28SingleValueDecodingContainerP6decodeyqd__qd__mKSeRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : SingleValueDecodingContainer, T : Decodable>",
-          "throwing": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -18747,35 +18822,28 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s28SingleValueDecodingContainerP6decodeyqd__qd__mKSeRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : SingleValueDecodingContainer, T : Decodable>",
+          "protocolReq": true,
+          "throwing": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s28SingleValueDecodingContainerP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "CodingUserInfoKey",
       "printedName": "CodingUserInfoKey",
-      "declKind": "Struct",
-      "usr": "s:s17CodingUserInfoKeyV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "RawRepresentable",
-        "Equatable",
-        "Hashable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "RawValue",
           "printedName": "RawValue",
-          "declKind": "TypeAlias",
-          "usr": "s:s17CodingUserInfoKeyV8RawValuea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -18783,16 +18851,15 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s17CodingUserInfoKeyV8RawValuea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "rawValue",
           "printedName": "rawValue",
-          "declKind": "Var",
-          "usr": "s:s17CodingUserInfoKeyV8rawValueSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -18804,13 +18871,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17CodingUserInfoKeyV8rawValueSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -18818,27 +18878,28 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17CodingUserInfoKeyV8rawValueSSvg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17CodingUserInfoKeyV8rawValueSSvp",
+          "moduleName": "Swift",
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(rawValue:)",
-          "declKind": "Constructor",
-          "usr": "s:s17CodingUserInfoKeyV8rawValueABSgSS_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "CodingUserInfoKey?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -18846,7 +18907,8 @@
                   "printedName": "CodingUserInfoKey",
                   "usr": "s:s17CodingUserInfoKeyV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -18854,19 +18916,44 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17CodingUserInfoKeyV8rawValueABSgSS_tcfc",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "CodingUserInfoKey",
+              "printedName": "CodingUserInfoKey",
+              "usr": "s:s17CodingUserInfoKeyV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "CodingUserInfoKey",
+              "printedName": "CodingUserInfoKey",
+              "usr": "s:s17CodingUserInfoKeyV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17CodingUserInfoKeyV2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s17CodingUserInfoKeyV9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -18878,10 +18965,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17CodingUserInfoKeyV9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -18889,21 +18972,20 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17CodingUserInfoKeyV9hashValueSivg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17CodingUserInfoKeyV9hashValueSivp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s17CodingUserInfoKeyV4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -18916,45 +18998,40 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s17CodingUserInfoKeyV4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s17CodingUserInfoKeyV",
+      "moduleName": "Swift",
+      "conformingProtocols": [
+        "RawRepresentable",
+        "Equatable",
+        "Hashable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "EncodingError",
       "printedName": "EncodingError",
-      "declKind": "Enum",
-      "usr": "s:s13EncodingErrorO",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Error"
-      ],
       "children": [
         {
           "kind": "TypeDecl",
           "name": "Context",
           "printedName": "Context",
-          "declKind": "Struct",
-          "usr": "s:s13EncodingErrorO7ContextV",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "Var",
               "name": "codingPath",
               "printedName": "codingPath",
-              "declKind": "Var",
-              "usr": "s:s13EncodingErrorO7ContextV10codingPathSays9CodingKey_pGvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -18962,22 +19039,18 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 },
                 {
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s13EncodingErrorO7ContextV10codingPathSays9CodingKey_pGvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Array",
                       "printedName": "[CodingKey]",
-                      "usr": "s:Sa",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -18985,20 +19058,26 @@
                           "printedName": "CodingKey",
                           "usr": "s:s9CodingKeyP"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sa"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s13EncodingErrorO7ContextV10codingPathSays9CodingKey_pGvg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s13EncodingErrorO7ContextV10codingPathSays9CodingKey_pGvp",
+              "moduleName": "Swift",
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "debugDescription",
               "printedName": "debugDescription",
-              "declKind": "Var",
-              "usr": "s:s13EncodingErrorO7ContextV16debugDescriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -19010,10 +19089,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s13EncodingErrorO7ContextV16debugDescriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19021,24 +19096,28 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s13EncodingErrorO7ContextV16debugDescriptionSSvg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s13EncodingErrorO7ContextV16debugDescriptionSSvp",
+              "moduleName": "Swift",
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "underlyingError",
               "printedName": "underlyingError",
-              "declKind": "Var",
-              "usr": "s:s13EncodingErrorO7ContextV010underlyingB0s0B0_pSgvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Error?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19046,22 +19125,18 @@
                       "printedName": "Error",
                       "usr": "s:s5ErrorP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s13EncodingErrorO7ContextV010underlyingB0s0B0_pSgvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
                       "printedName": "Error?",
-                      "usr": "s:Sq",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -19069,20 +19144,26 @@
                           "printedName": "Error",
                           "usr": "s:s5ErrorP"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s13EncodingErrorO7ContextV010underlyingB0s0B0_pSgvg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s13EncodingErrorO7ContextV010underlyingB0s0B0_pSgvp",
+              "moduleName": "Swift",
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(codingPath:debugDescription:underlyingError:)",
-              "declKind": "Constructor",
-              "usr": "s:s13EncodingErrorO7ContextV10codingPath16debugDescription010underlyingB0ADSays9CodingKey_pG_SSs0B0_pSgtcfc",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -19094,7 +19175,6 @@
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19102,7 +19182,8 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 },
                 {
                   "kind": "TypeNominal",
@@ -19114,8 +19195,6 @@
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Error?",
-                  "hasDefaultArg": true,
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19123,20 +19202,24 @@
                       "printedName": "Error",
                       "usr": "s:s5ErrorP"
                     }
-                  ]
+                  ],
+                  "hasDefaultArg": true,
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s13EncodingErrorO7ContextV10codingPath16debugDescription010underlyingB0ADSays9CodingKey_pG_SSs0B0_pSgtcfc",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Struct",
+          "usr": "s:s13EncodingErrorO7ContextV",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "invalidValue",
           "printedName": "invalidValue",
-          "declKind": "EnumElement",
-          "usr": "s:s13EncodingErrorO12invalidValueyAByp_AB7ContextVtcABmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -19196,45 +19279,38 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s13EncodingErrorO12invalidValueyAByp_AB7ContextVtcABmF",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s13EncodingErrorO",
+      "moduleName": "Swift",
+      "conformingProtocols": [
+        "Error"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "DecodingError",
       "printedName": "DecodingError",
-      "declKind": "Enum",
-      "usr": "s:s13DecodingErrorO",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Error"
-      ],
       "children": [
         {
           "kind": "TypeDecl",
           "name": "Context",
           "printedName": "Context",
-          "declKind": "Struct",
-          "usr": "s:s13DecodingErrorO7ContextV",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "Var",
               "name": "codingPath",
               "printedName": "codingPath",
-              "declKind": "Var",
-              "usr": "s:s13DecodingErrorO7ContextV10codingPathSays9CodingKey_pGvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19242,22 +19318,18 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 },
                 {
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s13DecodingErrorO7ContextV10codingPathSays9CodingKey_pGvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Array",
                       "printedName": "[CodingKey]",
-                      "usr": "s:Sa",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -19265,20 +19337,26 @@
                           "printedName": "CodingKey",
                           "usr": "s:s9CodingKeyP"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sa"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s13DecodingErrorO7ContextV10codingPathSays9CodingKey_pGvg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s13DecodingErrorO7ContextV10codingPathSays9CodingKey_pGvp",
+              "moduleName": "Swift",
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "debugDescription",
               "printedName": "debugDescription",
-              "declKind": "Var",
-              "usr": "s:s13DecodingErrorO7ContextV16debugDescriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -19290,10 +19368,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s13DecodingErrorO7ContextV16debugDescriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19301,24 +19375,28 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s13DecodingErrorO7ContextV16debugDescriptionSSvg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s13DecodingErrorO7ContextV16debugDescriptionSSvp",
+              "moduleName": "Swift",
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "underlyingError",
               "printedName": "underlyingError",
-              "declKind": "Var",
-              "usr": "s:s13DecodingErrorO7ContextV010underlyingB0s0B0_pSgvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Error?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19326,22 +19404,18 @@
                       "printedName": "Error",
                       "usr": "s:s5ErrorP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s13DecodingErrorO7ContextV010underlyingB0s0B0_pSgvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
                       "printedName": "Error?",
-                      "usr": "s:Sq",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -19349,20 +19423,26 @@
                           "printedName": "Error",
                           "usr": "s:s5ErrorP"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s13DecodingErrorO7ContextV010underlyingB0s0B0_pSgvg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s13DecodingErrorO7ContextV010underlyingB0s0B0_pSgvp",
+              "moduleName": "Swift",
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(codingPath:debugDescription:underlyingError:)",
-              "declKind": "Constructor",
-              "usr": "s:s13DecodingErrorO7ContextV10codingPath16debugDescription010underlyingB0ADSays9CodingKey_pG_SSs0B0_pSgtcfc",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -19374,7 +19454,6 @@
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[CodingKey]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19382,7 +19461,8 @@
                       "printedName": "CodingKey",
                       "usr": "s:s9CodingKeyP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 },
                 {
                   "kind": "TypeNominal",
@@ -19394,8 +19474,6 @@
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Error?",
-                  "hasDefaultArg": true,
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -19403,20 +19481,24 @@
                       "printedName": "Error",
                       "usr": "s:s5ErrorP"
                     }
-                  ]
+                  ],
+                  "hasDefaultArg": true,
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s13DecodingErrorO7ContextV10codingPath16debugDescription010underlyingB0ADSays9CodingKey_pG_SSs0B0_pSgtcfc",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Struct",
+          "usr": "s:s13DecodingErrorO7ContextV",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "typeMismatch",
           "printedName": "typeMismatch",
-          "declKind": "EnumElement",
-          "usr": "s:s13DecodingErrorO12typeMismatchyABypXp_AB7ContextVtcABmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -19483,16 +19565,15 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s13DecodingErrorO12typeMismatchyABypXp_AB7ContextVtcABmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "valueNotFound",
           "printedName": "valueNotFound",
-          "declKind": "EnumElement",
-          "usr": "s:s13DecodingErrorO13valueNotFoundyABypXp_AB7ContextVtcABmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -19559,16 +19640,15 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s13DecodingErrorO13valueNotFoundyABypXp_AB7ContextVtcABmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "keyNotFound",
           "printedName": "keyNotFound",
-          "declKind": "EnumElement",
-          "usr": "s:s13DecodingErrorO11keyNotFoundyABs9CodingKey_p_AB7ContextVtcABmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -19629,16 +19709,15 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s13DecodingErrorO11keyNotFoundyABs9CodingKey_p_AB7ContextVtcABmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "dataCorrupted",
           "printedName": "dataCorrupted",
-          "declKind": "EnumElement",
-          "usr": "s:s13DecodingErrorO13dataCorruptedyA2B7ContextVcABmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -19660,7 +19739,6 @@
                       "kind": "TypeNominal",
                       "name": "Paren",
                       "printedName": "(DecodingError.Context)",
-                      "usr": "s:s13DecodingErrorO7ContextV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -19668,7 +19746,8 @@
                           "printedName": "DecodingError.Context",
                           "usr": "s:s13DecodingErrorO7ContextV"
                         }
-                      ]
+                      ],
+                      "usr": "s:s13DecodingErrorO7ContextV"
                     }
                   ]
                 },
@@ -19694,21 +19773,15 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s13DecodingErrorO13dataCorruptedyA2B7ContextVcABmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "dataCorruptedError",
           "printedName": "dataCorruptedError(forKey:in:debugDescription:)",
-          "declKind": "Func",
-          "usr": "s:s13DecodingErrorO013dataCorruptedB06forKey2in16debugDescriptionAB0F0Qz_xSSts05KeyedA17ContainerProtocolRzlFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<C where C : KeyedDecodingContainerProtocol>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -19732,20 +19805,17 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13DecodingErrorO013dataCorruptedB06forKey2in16debugDescriptionAB0F0Qz_xSSts05KeyedA17ContainerProtocolRzlFZ",
+          "moduleName": "Swift",
+          "genericSig": "<C where C : KeyedDecodingContainerProtocol>",
+          "static": true
         },
         {
           "kind": "Function",
           "name": "dataCorruptedError",
           "printedName": "dataCorruptedError(in:debugDescription:)",
-          "declKind": "Func",
-          "usr": "s:s13DecodingErrorO013dataCorruptedB02in16debugDescriptionABs07UnkeyedA9Container_p_SStFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -19765,20 +19835,16 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13DecodingErrorO013dataCorruptedB02in16debugDescriptionABs07UnkeyedA9Container_p_SStFZ",
+          "moduleName": "Swift",
+          "static": true
         },
         {
           "kind": "Function",
           "name": "dataCorruptedError",
           "printedName": "dataCorruptedError(in:debugDescription:)",
-          "declKind": "Func",
-          "usr": "s:s13DecodingErrorO013dataCorruptedB02in16debugDescriptionABs011SingleValueA9Container_p_SStFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -19798,152 +19864,140 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13DecodingErrorO013dataCorruptedB02in16debugDescriptionABs011SingleValueA9Container_p_SStFZ",
+          "moduleName": "Swift",
+          "static": true
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s13DecodingErrorO",
+      "moduleName": "Swift",
+      "conformingProtocols": [
+        "Error"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "IndexingIterator",
       "printedName": "IndexingIterator",
-      "declKind": "Struct",
-      "usr": "s:s16IndexingIteratorV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Elements where Elements : Collection>",
-      "conformingProtocols": [
-        "IteratorProtocol",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s16IndexingIteratorV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Elements.Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s16IndexingIteratorV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Elements where Elements : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s16IndexingIteratorV0B0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "IndexingIterator",
               "printedName": "IndexingIterator<Elements>",
-              "usr": "s:s16IndexingIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Elements"
                 }
-              ]
+              ],
+              "usr": "s:s16IndexingIteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s16IndexingIteratorV0B0a",
+          "moduleName": "Swift",
+          "genericSig": "<Elements where Elements : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s16IndexingIteratorV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Elements.Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Elements.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s16IndexingIteratorV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Elements where Elements : Collection>"
         },
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s16IndexingIteratorV4next7ElementQzSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Elements.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Elements.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16IndexingIteratorV4next7ElementQzSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<Elements where Elements : Collection>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ],
+          "mutating": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s16IndexingIteratorV",
+      "moduleName": "Swift",
+      "genericSig": "<Elements where Elements : Collection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol",
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Collection",
       "printedName": "Collection",
-      "declKind": "Protocol",
-      "usr": "s:Sl",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Sequence, Self.Index : Comparable, Self.Index == Self.Indices.Element, Self.Indices : Collection, Self.Indices == Self.Indices.SubSequence, Self.SubSequence : Collection, Self.Indices.Element == Self.Indices.Index, Self.Indices.Index == Self.SubSequence.Index, Self.SubSequence.Index == Self.Indices.Indices.Element, Self.Indices.Indices.Element == Self.Indices.Indices.Index, Self.Indices.Indices.Index == Self.SubSequence.Indices.Element, Self.SubSequence.Indices.Element == Self.SubSequence.Indices.Index, Self.SubSequence.Indices.Index == Self.SubSequence.Indices.Indices.Element, Self.SubSequence.Indices.Indices.Element == Self.SubSequence.Indices.Indices.Index>",
-      "conformingProtocols": [
-        "Sequence"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "IndexDistance",
           "printedName": "IndexDistance",
-          "declKind": "TypeAlias",
-          "usr": "s:Sl13IndexDistancea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -19951,16 +20005,39 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sl13IndexDistancea",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
+          "kind": "AssociatedType",
+          "name": "Element",
+          "printedName": "Element",
+          "declKind": "AssociatedType",
+          "usr": "s:Sl7ElementQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Index",
+          "printedName": "Index",
+          "declKind": "AssociatedType",
+          "usr": "s:Sl5IndexQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:Sl10startIndex0B0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -19971,29 +20048,28 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sl10startIndex0B0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sl10startIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Collection>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sl10startIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:Sl8endIndex0B0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -20004,46 +20080,175 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sl8endIndex0B0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sl8endIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Collection>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sl8endIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Iterator",
+          "printedName": "Iterator",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "IndexingIterator",
+              "printedName": "IndexingIterator<Self>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "usr": "s:s16IndexingIteratorV"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:Sl8IteratorQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:Sl12makeIterator0B0QzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Iterator"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl12makeIterator0B0QzyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
+          "kind": "AssociatedType",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<Self>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:Sl11SubSequenceQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Index"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Sly7ElementQz5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.SubSequence"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Self.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "Self.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Sly11SubSequenceQzSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Indices",
+          "printedName": "Indices",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DefaultIndices",
+              "printedName": "DefaultIndices<Self>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "usr": "s:SI"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:Sl7IndicesQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:Sl7indices7IndicesQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -20054,30 +20259,28 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sl7indices7IndicesQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Indices"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sl7indices7IndicesQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Collection>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sl7indices7IndicesQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(upTo:)",
-          "declKind": "Func",
-          "usr": "s:Sl6prefix4upTo11SubSequenceQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -20089,17 +20292,17 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl6prefix4upTo11SubSequenceQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(from:)",
-          "declKind": "Func",
-          "usr": "s:Sl6suffix4from11SubSequenceQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -20111,17 +20314,17 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl6suffix4from11SubSequenceQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(through:)",
-          "declKind": "Func",
-          "usr": "s:Sl6prefix7through11SubSequenceQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -20133,16 +20336,17 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl6prefix7through11SubSequenceQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "isEmpty",
           "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:Sl7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -20154,11 +20358,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sl7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -20166,18 +20365,22 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sl7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Collection>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sl7isEmptySbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:Sl5countSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -20189,11 +20392,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sl5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -20201,68 +20399,70 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sl5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Collection>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sl5countSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "first",
           "printedName": "first",
-          "declKind": "Var",
-          "usr": "s:Sl5first7ElementQzSgvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sl5first7ElementQzSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Self.Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Self.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sl5first7ElementQzSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Collection>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sl5first7ElementQzSgvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:Sl5index_8offsetBy5IndexQzAD_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -20280,30 +20480,30 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl5index_8offsetBy5IndexQzAD_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:Sl5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -20321,17 +20521,17 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:Sl8distance4from2toSi5IndexQz_AEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -20349,17 +20549,17 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl8distance4from2toSi5IndexQz_AEtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:Sl5index5after5IndexQzAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -20371,17 +20571,17 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl5index5after5IndexQzAD_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:Sl9formIndex5aftery0B0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -20393,46 +20593,42 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sl9formIndex5aftery0B0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Index"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SlsE9formIndex5aftery0B0Qzz_tF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Collection>",
           "declAttributes": [
             "Inline",
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Index"
-            }
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SlsE5index_8offsetBy5IndexQzAD_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -20450,33 +20646,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE5index_8offsetBy5IndexQzAD_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SlsE5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -20494,20 +20689,19 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SlsE9formIndex_8offsetByy0B0Qzz_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -20525,20 +20719,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE9formIndex_8offsetByy0B0Qzz_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SlsE9formIndex_8offsetBy07limitedD0Sb0B0Qzz_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -20562,20 +20755,19 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE9formIndex_8offsetBy07limitedD0Sb0B0Qzz_SiAEtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SlsE8distance4from2toSi5IndexQz_AEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -20593,138 +20785,174 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE8distance4from2toSi5IndexQz_AEtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "randomElement",
           "printedName": "randomElement(using:)",
-          "declKind": "Func",
-          "usr": "s:SlsE13randomElement5using0B0QzSgqd__z_tSGRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Collection, T : RandomNumberGenerator>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE13randomElement5using0B0QzSgqd__z_tSGRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : Collection, T : RandomNumberGenerator>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "randomElement",
           "printedName": "randomElement()",
-          "declKind": "Func",
-          "usr": "s:SlsE13randomElement0B0QzSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE13randomElement0B0QzSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:Slss16IndexingIteratorVyxG0B0RtzrlE04makeB0ACyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection, Self.Iterator == IndexingIterator<Self>>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "IndexingIterator",
               "printedName": "IndexingIterator<Self>",
-              "usr": "s:s16IndexingIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:s16IndexingIteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Slss16IndexingIteratorVyxG0B0RtzrlE04makeB0ACyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection, Self.Iterator == IndexingIterator<Self>>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<Self>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Self.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "Self.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Slss5SliceVyxG11SubSequenceRtzrlEyACSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection, Self.SubSequence == Slice<Self>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "popFirst",
           "printedName": "popFirst()",
-          "declKind": "Func",
-          "usr": "s:Sls11SubSequenceQzRszrlE8popFirst7ElementQzSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sls11SubSequenceQzRszrlE8popFirst7ElementQzSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection, Self == Self.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Var",
           "name": "isEmpty",
           "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:SlsE7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -20736,11 +20964,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SlsE7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -20748,76 +20971,77 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SlsE7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SlsE7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "first",
           "printedName": "first",
-          "declKind": "Var",
-          "usr": "s:SlsE5first7ElementQzSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SlsE5first7ElementQzSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
-              "declAttributes": [
-                "Inline"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Self.Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Self.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SlsE5first7ElementQzSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Collection>",
+              "declAttributes": [
+                "Inline"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SlsE5first7ElementQzSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:SlsE19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -20829,11 +21053,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SlsE19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -20841,21 +21060,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SlsE19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SlsE19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:SlsE5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -20867,11 +21089,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SlsE5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -20879,45 +21096,42 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SlsE5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SlsE5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:SlsE3mapySayqd__Gqd__7ElementQzKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Collection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[T]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> T",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -20936,22 +21150,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE3mapySayqd__Gqd__7ElementQzKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : Collection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:SlsE9dropFirsty11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -20964,20 +21182,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE9dropFirsty11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:SlsE8dropLasty11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -20990,22 +21207,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE8dropLasty11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:SlsE4drop5while11SubSequenceQzSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -21016,9 +21230,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -21038,22 +21249,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE4drop5while11SubSequenceQzSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(_:)",
-          "declKind": "Func",
-          "usr": "s:SlsE6prefixy11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -21066,22 +21281,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE6prefixy11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:SlsE6prefix5while11SubSequenceQzSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -21092,9 +21304,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -21114,22 +21323,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE6prefix5while11SubSequenceQzSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:SlsE6suffixy11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -21142,20 +21355,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE6suffixy11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(upTo:)",
-          "declKind": "Func",
-          "usr": "s:SlsE6prefix4upTo11SubSequenceQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -21167,20 +21379,19 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE6prefix4upTo11SubSequenceQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(from:)",
-          "declKind": "Func",
-          "usr": "s:SlsE6suffix4from11SubSequenceQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -21192,20 +21403,19 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE6suffix4from11SubSequenceQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(through:)",
-          "declKind": "Func",
-          "usr": "s:SlsE6prefix7through11SubSequenceQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -21217,35 +21427,32 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE6prefix7through11SubSequenceQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(maxSplits:omittingEmptySubsequences:whereSeparator:)",
-          "declKind": "Func",
-          "usr": "s:SlsE5split9maxSplits25omittingEmptySubsequences14whereSeparatorSay11SubSequenceQzGSi_S2b7ElementQzKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Self.SubSequence]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.SubSequence"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -21265,9 +21472,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -21287,35 +21491,39 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE5split9maxSplits25omittingEmptySubsequences14whereSeparatorSay11SubSequenceQzGSi_S2b7ElementQzKXEtKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(separator:maxSplits:omittingEmptySubsequences:)",
-          "declKind": "Func",
-          "usr": "s:SlsSQ7ElementRpzrlE5split9separator9maxSplits25omittingEmptySubsequencesSay11SubSequenceQzGAB_SiSbtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection, Self.Element : Equatable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Self.SubSequence]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.SubSequence"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -21336,43 +21544,40 @@
               "hasDefaultArg": true,
               "usr": "s:Sb"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsSQ7ElementRpzrlE5split9separator9maxSplits25omittingEmptySubsequencesSay11SubSequenceQzGAB_SiSbtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection, Self.Element : Equatable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "removeFirst",
           "printedName": "removeFirst()",
-          "declKind": "Func",
-          "usr": "s:Sls11SubSequenceQzRszrlE11removeFirst7ElementQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sls11SubSequenceQzRszrlE11removeFirst7ElementQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection, Self == Self.SubSequence>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeFirst",
           "printedName": "removeFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:Sls11SubSequenceQzRszrlE11removeFirstyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -21385,76 +21590,70 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sls11SubSequenceQzRszrlE11removeFirstyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection, Self == Self.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "firstIndex",
           "printedName": "firstIndex(of:)",
-          "declKind": "Func",
-          "usr": "s:SlsSQ7ElementRpzrlE10firstIndex2of0C0QzSgAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection, Self.Element : Equatable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsSQ7ElementRpzrlE10firstIndex2of0C0QzSgAB_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection, Self.Element : Equatable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "firstIndex",
           "printedName": "firstIndex(where:)",
-          "declKind": "Func",
-          "usr": "s:SlsE10firstIndex5where0B0QzSgSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -21474,155 +21673,225 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE10firstIndex5where0B0QzSgSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "joined",
           "printedName": "joined()",
-          "declKind": "Func",
-          "usr": "s:SlsSl7ElementRpzrlE6joineds17FlattenCollectionVyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection, Self.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "FlattenCollection",
               "printedName": "FlattenCollection<Self>",
-              "usr": "s:s17FlattenCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:s17FlattenCollectionV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsSl7ElementRpzrlE6joineds17FlattenCollectionVyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection, Self.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:SlsSIyxG7IndicesRtzrlE7indicesAAvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DefaultIndices",
               "printedName": "DefaultIndices<Self>",
-              "usr": "s:SI",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:SI"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SlsSIyxG7IndicesRtzrlE7indicesAAvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection, Self.Indices == DefaultIndices<Self>>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DefaultIndices",
                   "printedName": "DefaultIndices<Self>",
-                  "usr": "s:SI",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Self"
                     }
-                  ]
+                  ],
+                  "usr": "s:SI"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SlsSIyxG7IndicesRtzrlE7indicesAAvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Collection, Self.Indices == DefaultIndices<Self>>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SlsSIyxG7IndicesRtzrlE7indicesAAvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "lazy",
           "printedName": "lazy",
-          "declKind": "Var",
-          "usr": "s:SlsE4lazys14LazyCollectionVyxGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyCollection",
               "printedName": "LazyCollection<Self>",
-              "usr": "s:s14LazyCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:s14LazyCollectionV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SlsE4lazys14LazyCollectionVyxGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "LazyCollection",
                   "printedName": "LazyCollection<Self>",
-                  "usr": "s:s14LazyCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Self"
                     }
-                  ]
+                  ],
+                  "usr": "s:s14LazyCollectionV"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SlsE4lazys14LazyCollectionVyxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SlsE4lazys14LazyCollectionVyxGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.SubSequence"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "R"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SlsEy11SubSequenceQzqd__cSXRd__5BoundQyd__5IndexRtzluip",
+          "moduleName": "Swift",
+          "genericSig": "<Self, R where Self : Collection, R : RangeExpression, Self.Index == R.Bound>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.SubSequence"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnboundedRange_) -> ()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Paren",
+                  "printedName": "(UnboundedRange_)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnboundedRange_",
+                      "printedName": "UnboundedRange_",
+                      "usr": "s:s15UnboundedRange_O"
+                    }
+                  ],
+                  "usr": "s:s15UnboundedRange_O"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SlsEy11SubSequenceQzys15UnboundedRange_OXEcip",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SlsE5index_8offsetBy5IndexQzAD_qd__tSzRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Collection, T : BinaryInteger>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -21639,21 +21908,20 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE5index_8offsetBy5IndexQzAD_qd__tSzRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : Collection, T : BinaryInteger>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SlsE9formIndex_8offsetByy0B0Qzz_qd__tSzRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Collection, T : BinaryInteger>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -21670,34 +21938,33 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE9formIndex_8offsetByy0B0Qzz_qd__tSzRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : Collection, T : BinaryInteger>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SlsE5index_8offsetBy07limitedC05IndexQzSgAE_qd__AEtSzRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Collection, T : BinaryInteger>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -21714,21 +21981,20 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE5index_8offsetBy07limitedC05IndexQzSgAE_qd__AEtSzRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : Collection, T : BinaryInteger>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SlsE9formIndex_8offsetBy07limitedD0Sb0B0Qzz_qd__AEtSzRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Collection, T : BinaryInteger>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -21751,21 +22017,20 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE9formIndex_8offsetBy07limitedD0Sb0B0Qzz_qd__AEtSzRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : Collection, T : BinaryInteger>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SlsE8distance4from2toqd__5IndexQz_AEtSzRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Collection, T : BinaryInteger>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -21782,28 +22047,25 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE8distance4from2toqd__5IndexQz_AEtSzRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : Collection, T : BinaryInteger>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "flatMap",
           "printedName": "flatMap(_:)",
-          "declKind": "Func",
-          "usr": "s:SlsE7flatMapySaySSGSSSg7ElementQzKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Collection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[String]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -21811,21 +22073,18 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> String?",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "String?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -21833,7 +22092,8 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -21847,19 +22107,460 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsE7flatMapySaySSGSSSg7ElementQzKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection>",
+          "deprecated": true,
+          "declAttributes": [
+            "Rethrows",
+            "Available"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Self.Index?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "Self.Index"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Element"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SlsSQ7ElementRpzrlE5index2of5IndexQzSgAB_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Collection, Self.Element : Equatable>",
+          "declAttributes": [
+            "Inlinable",
+            "Available"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:Sl",
+      "moduleName": "Swift",
+      "genericSig": "<Self : Sequence, Self.Index : Comparable, Self.Index == Self.Indices.Element, Self.Indices : Collection, Self.Indices == Self.Indices.SubSequence, Self.SubSequence : Collection, Self.Indices.Element == Self.Indices.Index, Self.Indices.Index == Self.SubSequence.Index, Self.SubSequence.Index == Self.Indices.Indices.Element, Self.Indices.Indices.Element == Self.Indices.Indices.Index, Self.Indices.Indices.Index == Self.SubSequence.Indices.Element, Self.SubSequence.Indices.Element == Self.SubSequence.Indices.Index, Self.SubSequence.Indices.Index == Self.SubSequence.Indices.Indices.Element, Self.SubSequence.Indices.Indices.Element == Self.SubSequence.Indices.Indices.Index>",
+      "conformingProtocols": [
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Comparable",
       "printedName": "Comparable",
+      "children": [
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SL1loiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Comparable>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SL2leoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Comparable>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SL2geoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Comparable>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SL1goiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Comparable>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SLsE1goiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SLsE2leoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SLsE2geoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "...",
+          "printedName": "...(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<Self>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "usr": "s:SN"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SLsE3zzzoiySNyxGx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "..<",
+          "printedName": "..<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Self>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SLsE3zzloiySnyxGx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "..<",
+          "printedName": "..<(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "PartialRangeUpTo",
+              "printedName": "PartialRangeUpTo<Self>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "usr": "s:s16PartialRangeUpToV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SLsE3zzlopys16PartialRangeUpToVyxGxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "...",
+          "printedName": "...(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "PartialRangeThrough",
+              "printedName": "PartialRangeThrough<Self>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "usr": "s:s19PartialRangeThroughV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SLsE3zzzopys19PartialRangeThroughVyxGxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "...",
+          "printedName": "...(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "PartialRangeFrom",
+              "printedName": "PartialRangeFrom<Self>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "usr": "s:s16PartialRangeFromV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SLsE3zzzoPys16PartialRangeFromVyxGxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Postfix",
+            "Transparent"
+          ]
+        }
+      ],
       "declKind": "Protocol",
       "usr": "s:SL",
-      "location": "",
       "moduleName": "Swift",
       "genericSig": "<Self : Equatable>",
       "conformingProtocols": [
@@ -21870,49 +22571,50 @@
       "kind": "TypeDecl",
       "name": "RawRepresentable",
       "printedName": "RawRepresentable",
-      "declKind": "Protocol",
-      "usr": "s:SY",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "RawValue",
+          "printedName": "RawValue",
+          "declKind": "AssociatedType",
+          "usr": "s:SY8RawValueQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(rawValue:)",
-          "declKind": "Constructor",
-          "usr": "s:SY8rawValuexSg03RawB0Qz_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RawRepresentable>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.RawValue"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SY8rawValuexSg03RawB0Qz_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RawRepresentable>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "rawValue",
           "printedName": "rawValue",
-          "declKind": "Var",
-          "usr": "s:SY8rawValue03RawB0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -21923,709 +22625,603 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SY8rawValue03RawB0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : RawRepresentable>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.RawValue"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SY8rawValue03RawB0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : RawRepresentable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SY8rawValue03RawB0Qzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzSb8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == Bool>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzSb8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == Bool>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzSS8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == String>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzSS8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == String>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzSd8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == Double>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzSd8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == Double>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzSf8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == Float>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzSf8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == Float>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzSi8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == Int>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzSi8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == Int>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzs4Int8V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == Int8>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzs4Int8V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == Int8>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzs5Int16V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == Int16>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzs5Int16V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == Int16>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzs5Int32V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == Int32>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzs5Int32V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == Int32>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzs5Int64V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == Int64>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzs5Int64V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == Int64>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzSu8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == UInt>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzSu8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == UInt>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzs5UInt8V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == UInt8>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzs5UInt8V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == UInt8>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzs6UInt16V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == UInt16>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Decoder",
+              "printedName": "Decoder",
+              "usr": "s:s7DecoderP"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SYsSeRzs6UInt16V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == UInt16>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Decoder",
-              "printedName": "Decoder",
-              "usr": "s:s7DecoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Encoder",
+              "printedName": "Encoder",
+              "usr": "s:s7EncoderP"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SYsSERzs6UInt32V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == UInt32>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Encoder",
-              "printedName": "Encoder",
-              "usr": "s:s7EncoderP"
-            }
-          ]
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:SYsSeRzs6UInt32V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == UInt32>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -22638,21 +23234,17 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SYsSeRzs6UInt32V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == UInt32>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:SYsSERzs6UInt64V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == UInt64>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -22665,21 +23257,17 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SYsSERzs6UInt64V8RawValueSYRtzrlE6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Encodable, Self : RawRepresentable, Self.RawValue == UInt64>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:SYsSeRzs6UInt64V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == UInt64>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -22692,29 +23280,126 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SYsSeRzs6UInt64V8RawValueSYRtzrlE4fromxs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Decodable, Self : RawRepresentable, Self.RawValue == UInt64>",
+          "throwing": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SY",
+      "moduleName": "Swift"
+    },
+    {
+      "kind": "Function",
+      "name": "==",
+      "printedName": "==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "T"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "T"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2eeoiySbx_xtSYRzSQ8RawValueRpzlF",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : RawRepresentable, T.RawValue : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "T"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "T"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbx_xtSYRzSQ8RawValueRpzlF",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : RawRepresentable, T.RawValue : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "T"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "T"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbx_xtSQRzSYRzSQ8RawValueSYRpzlF",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : Equatable, T : RawRepresentable, T.RawValue : Equatable>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "CaseIterable",
       "printedName": "CaseIterable",
-      "declKind": "Protocol",
-      "usr": "s:s12CaseIterableP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self == Self.AllCases.Element, Self.AllCases : Collection>",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "AllCases",
+          "printedName": "AllCases",
+          "declKind": "AssociatedType",
+          "usr": "s:s12CaseIterableP8AllCasesQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Var",
           "name": "allCases",
           "printedName": "allCases",
-          "declKind": "Var",
-          "usr": "s:s12CaseIterableP8allCases03AllD0QzvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -22725,42 +23410,41 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12CaseIterableP8allCases03AllD0QzvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CaseIterable>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.AllCases"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12CaseIterableP8allCases03AllD0QzvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : CaseIterable>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s12CaseIterableP8allCases03AllD0QzvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s12CaseIterableP",
+      "moduleName": "Swift",
+      "genericSig": "<Self == Self.AllCases.Element, Self.AllCases : Collection>"
     },
     {
       "kind": "TypeDecl",
       "name": "ExpressibleByNilLiteral",
       "printedName": "ExpressibleByNilLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s23ExpressibleByNilLiteralP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(nilLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s23ExpressibleByNilLiteralP03nilD0xyt_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByNilLiteral>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -22772,29 +23456,36 @@
               "name": "Void",
               "printedName": "()"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s23ExpressibleByNilLiteralP03nilD0xyt_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : ExpressibleByNilLiteral>",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s23ExpressibleByNilLiteralP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "ExpressibleByIntegerLiteral",
       "printedName": "ExpressibleByIntegerLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s27ExpressibleByIntegerLiteralP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self.IntegerLiteralType : _ExpressibleByBuiltinIntegerLiteral>",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "IntegerLiteralType",
+          "printedName": "IntegerLiteralType",
+          "declKind": "AssociatedType",
+          "usr": "s:s27ExpressibleByIntegerLiteralP0cD4TypeQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(integerLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s27ExpressibleByIntegerLiteralP07integerD0x0cD4TypeQz_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByIntegerLiteral>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -22806,20 +23497,17 @@
               "name": "DependentMember",
               "printedName": "Self.IntegerLiteralType"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s27ExpressibleByIntegerLiteralP07integerD0x0cD4TypeQz_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : ExpressibleByIntegerLiteral>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(integerLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s27ExpressibleByIntegerLiteralPss01_ab7BuiltincD0RzrlE07integerD0xx_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByIntegerLiteral, Self : _ExpressibleByBuiltinIntegerLiteral>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -22831,29 +23519,39 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s27ExpressibleByIntegerLiteralPss01_ab7BuiltincD0RzrlE07integerD0xx_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : ExpressibleByIntegerLiteral, Self : _ExpressibleByBuiltinIntegerLiteral>",
+          "declAttributes": [
+            "Transparent"
           ]
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s27ExpressibleByIntegerLiteralP",
+      "moduleName": "Swift",
+      "genericSig": "<Self.IntegerLiteralType : _ExpressibleByBuiltinIntegerLiteral>"
     },
     {
       "kind": "TypeDecl",
       "name": "ExpressibleByFloatLiteral",
       "printedName": "ExpressibleByFloatLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s25ExpressibleByFloatLiteralP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self.FloatLiteralType : _ExpressibleByBuiltinFloatLiteral>",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "FloatLiteralType",
+          "printedName": "FloatLiteralType",
+          "declKind": "AssociatedType",
+          "usr": "s:s25ExpressibleByFloatLiteralP0cD4TypeQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(floatLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s25ExpressibleByFloatLiteralP05floatD0x0cD4TypeQz_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByFloatLiteral>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -22865,29 +23563,37 @@
               "name": "DependentMember",
               "printedName": "Self.FloatLiteralType"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s25ExpressibleByFloatLiteralP05floatD0x0cD4TypeQz_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : ExpressibleByFloatLiteral>",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s25ExpressibleByFloatLiteralP",
+      "moduleName": "Swift",
+      "genericSig": "<Self.FloatLiteralType : _ExpressibleByBuiltinFloatLiteral>"
     },
     {
       "kind": "TypeDecl",
       "name": "ExpressibleByBooleanLiteral",
       "printedName": "ExpressibleByBooleanLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s27ExpressibleByBooleanLiteralP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self.BooleanLiteralType : _ExpressibleByBuiltinBooleanLiteral>",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "BooleanLiteralType",
+          "printedName": "BooleanLiteralType",
+          "declKind": "AssociatedType",
+          "usr": "s:s27ExpressibleByBooleanLiteralP0cD4TypeQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(booleanLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s27ExpressibleByBooleanLiteralP07booleanD0x0cD4TypeQz_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByBooleanLiteral>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -22899,29 +23605,37 @@
               "name": "DependentMember",
               "printedName": "Self.BooleanLiteralType"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s27ExpressibleByBooleanLiteralP07booleanD0x0cD4TypeQz_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : ExpressibleByBooleanLiteral>",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s27ExpressibleByBooleanLiteralP",
+      "moduleName": "Swift",
+      "genericSig": "<Self.BooleanLiteralType : _ExpressibleByBuiltinBooleanLiteral>"
     },
     {
       "kind": "TypeDecl",
       "name": "ExpressibleByUnicodeScalarLiteral",
       "printedName": "ExpressibleByUnicodeScalarLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s33ExpressibleByUnicodeScalarLiteralP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self.UnicodeScalarLiteralType : _ExpressibleByBuiltinUnicodeScalarLiteral>",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "UnicodeScalarLiteralType",
+          "printedName": "UnicodeScalarLiteralType",
+          "declKind": "AssociatedType",
+          "usr": "s:s33ExpressibleByUnicodeScalarLiteralP0cdE4TypeQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(unicodeScalarLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s33ExpressibleByUnicodeScalarLiteralP07unicodedE0x0cdE4TypeQz_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByUnicodeScalarLiteral>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -22933,32 +23647,37 @@
               "name": "DependentMember",
               "printedName": "Self.UnicodeScalarLiteralType"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s33ExpressibleByUnicodeScalarLiteralP07unicodedE0x0cdE4TypeQz_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : ExpressibleByUnicodeScalarLiteral>",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s33ExpressibleByUnicodeScalarLiteralP",
+      "moduleName": "Swift",
+      "genericSig": "<Self.UnicodeScalarLiteralType : _ExpressibleByBuiltinUnicodeScalarLiteral>"
     },
     {
       "kind": "TypeDecl",
       "name": "ExpressibleByExtendedGraphemeClusterLiteral",
       "printedName": "ExpressibleByExtendedGraphemeClusterLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s43ExpressibleByExtendedGraphemeClusterLiteralP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : ExpressibleByUnicodeScalarLiteral, Self.ExtendedGraphemeClusterLiteralType : _ExpressibleByBuiltinExtendedGraphemeClusterLiteral>",
-      "conformingProtocols": [
-        "ExpressibleByUnicodeScalarLiteral"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "ExtendedGraphemeClusterLiteralType",
+          "printedName": "ExtendedGraphemeClusterLiteralType",
+          "declKind": "AssociatedType",
+          "usr": "s:s43ExpressibleByExtendedGraphemeClusterLiteralP0cdeF4TypeQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(extendedGraphemeClusterLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s43ExpressibleByExtendedGraphemeClusterLiteralP08extendeddeF0x0cdeF4TypeQz_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByExtendedGraphemeClusterLiteral>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -22970,20 +23689,17 @@
               "name": "DependentMember",
               "printedName": "Self.ExtendedGraphemeClusterLiteralType"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s43ExpressibleByExtendedGraphemeClusterLiteralP08extendeddeF0x0cdeF4TypeQz_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : ExpressibleByExtendedGraphemeClusterLiteral>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(unicodeScalarLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s43ExpressibleByExtendedGraphemeClusterLiteralPs013UnicodeScalarF4TypeQz0cdefI0RtzrlE07unicodehF0xAF_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByExtendedGraphemeClusterLiteral, Self.ExtendedGraphemeClusterLiteralType == Self.UnicodeScalarLiteralType>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -22995,33 +23711,42 @@
               "name": "DependentMember",
               "printedName": "Self.ExtendedGraphemeClusterLiteralType"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s43ExpressibleByExtendedGraphemeClusterLiteralPs013UnicodeScalarF4TypeQz0cdefI0RtzrlE07unicodehF0xAF_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : ExpressibleByExtendedGraphemeClusterLiteral, Self.ExtendedGraphemeClusterLiteralType == Self.UnicodeScalarLiteralType>",
+          "declAttributes": [
+            "Transparent"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s43ExpressibleByExtendedGraphemeClusterLiteralP",
+      "moduleName": "Swift",
+      "genericSig": "<Self : ExpressibleByUnicodeScalarLiteral, Self.ExtendedGraphemeClusterLiteralType : _ExpressibleByBuiltinExtendedGraphemeClusterLiteral>",
+      "conformingProtocols": [
+        "ExpressibleByUnicodeScalarLiteral"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "ExpressibleByStringLiteral",
       "printedName": "ExpressibleByStringLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s26ExpressibleByStringLiteralP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : ExpressibleByExtendedGraphemeClusterLiteral, Self.StringLiteralType : _ExpressibleByBuiltinStringLiteral>",
-      "conformingProtocols": [
-        "ExpressibleByExtendedGraphemeClusterLiteral",
-        "ExpressibleByUnicodeScalarLiteral"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "StringLiteralType",
+          "printedName": "StringLiteralType",
+          "declKind": "AssociatedType",
+          "usr": "s:s26ExpressibleByStringLiteralP0cD4TypeQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(stringLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s26ExpressibleByStringLiteralP06stringD0x0cD4TypeQz_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByStringLiteral>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -23033,20 +23758,17 @@
               "name": "DependentMember",
               "printedName": "Self.StringLiteralType"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s26ExpressibleByStringLiteralP06stringD0x0cD4TypeQz_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : ExpressibleByStringLiteral>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(extendedGraphemeClusterLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s26ExpressibleByStringLiteralPs0cD4TypeQz023ExtendedGraphemeClusterdE0RtzrlE08extendedghD0xAF_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByStringLiteral, Self.ExtendedGraphemeClusterLiteralType == Self.StringLiteralType>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -23058,28 +23780,43 @@
               "name": "DependentMember",
               "printedName": "Self.StringLiteralType"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s26ExpressibleByStringLiteralPs0cD4TypeQz023ExtendedGraphemeClusterdE0RtzrlE08extendedghD0xAF_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : ExpressibleByStringLiteral, Self.ExtendedGraphemeClusterLiteralType == Self.StringLiteralType>",
+          "declAttributes": [
+            "Transparent"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s26ExpressibleByStringLiteralP",
+      "moduleName": "Swift",
+      "genericSig": "<Self : ExpressibleByExtendedGraphemeClusterLiteral, Self.StringLiteralType : _ExpressibleByBuiltinStringLiteral>",
+      "conformingProtocols": [
+        "ExpressibleByExtendedGraphemeClusterLiteral",
+        "ExpressibleByUnicodeScalarLiteral"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "ExpressibleByArrayLiteral",
       "printedName": "ExpressibleByArrayLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s25ExpressibleByArrayLiteralP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "ArrayLiteralElement",
+          "printedName": "ArrayLiteralElement",
+          "declKind": "AssociatedType",
+          "usr": "s:s25ExpressibleByArrayLiteralP0cD7ElementQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(arrayLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s25ExpressibleByArrayLiteralP05arrayD0x0cD7ElementQzd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByArrayLiteral>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -23090,37 +23827,54 @@
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Self.ArrayLiteralElement]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.ArrayLiteralElement"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s25ExpressibleByArrayLiteralP05arrayD0x0cD7ElementQzd_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : ExpressibleByArrayLiteral>",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s25ExpressibleByArrayLiteralP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "ExpressibleByDictionaryLiteral",
       "printedName": "ExpressibleByDictionaryLiteral",
-      "declKind": "Protocol",
-      "usr": "s:s30ExpressibleByDictionaryLiteralP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Key",
+          "printedName": "Key",
+          "declKind": "AssociatedType",
+          "usr": "s:s30ExpressibleByDictionaryLiteralP3KeyQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Value",
+          "printedName": "Value",
+          "declKind": "AssociatedType",
+          "usr": "s:s30ExpressibleByDictionaryLiteralP5ValueQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(dictionaryLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s30ExpressibleByDictionaryLiteralP010dictionaryD0x3KeyQz_5ValueQztd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ExpressibleByDictionaryLiteral>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -23131,7 +23885,6 @@
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[(Self.Key, Self.Value)]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -23150,24 +23903,25 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s30ExpressibleByDictionaryLiteralP010dictionaryD0x3KeyQz_5ValueQztd_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : ExpressibleByDictionaryLiteral>",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s30ExpressibleByDictionaryLiteralP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "ExpressibleByStringInterpolation",
       "printedName": "ExpressibleByStringInterpolation",
-      "declKind": "TypeAlias",
-      "usr": "s:s32ExpressibleByStringInterpolationa",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -23175,46 +23929,24 @@
           "printedName": "_ExpressibleByStringInterpolation",
           "usr": "s:s33_ExpressibleByStringInterpolationP"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s32ExpressibleByStringInterpolationa",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "ContiguousArray",
       "printedName": "ContiguousArray",
-      "declKind": "Struct",
-      "usr": "s:s15ContiguousArrayV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "_DestructorSafeContainer",
-        "RandomAccessCollection",
-        "MutableCollection",
-        "BidirectionalCollection",
-        "Collection",
-        "Sequence",
-        "ExpressibleByArrayLiteral",
-        "RangeReplaceableCollection",
-        "ArrayProtocol",
-        "CustomReflectable",
-        "CustomStringConvertible",
-        "CustomDebugStringConvertible",
-        "Equatable",
-        "Hashable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s15ContiguousArrayV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -23222,23 +23954,21 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15ContiguousArrayV5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s15ContiguousArrayV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Int>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -23246,54 +23976,51 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15ContiguousArrayV7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s15ContiguousArrayV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "IndexingIterator",
               "printedName": "IndexingIterator<ContiguousArray<Element>>",
-              "usr": "s:s16IndexingIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ContiguousArray",
                   "printedName": "ContiguousArray<Element>",
-                  "usr": "s:s15ContiguousArrayV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s15ContiguousArrayV"
                 }
-              ]
+              ],
+              "usr": "s:s16IndexingIteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15ContiguousArrayV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s15ContiguousArrayV10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -23305,11 +24032,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15ContiguousArrayV10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -23317,21 +24039,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15ContiguousArrayV10startIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15ContiguousArrayV10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s15ContiguousArrayV8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -23343,14 +24068,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15ContiguousArrayV8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -23358,22 +24075,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15ContiguousArrayV8endIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>",
+              "declAttributes": [
+                "Inlinable"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s15ContiguousArrayV8endIndexSivp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV5index5afterS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -23387,20 +24106,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV5index5afterS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV9formIndex5afterySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -23413,20 +24131,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV9formIndex5afterySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV5index6beforeS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -23440,20 +24157,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV5index6beforeS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV9formIndex6beforeySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -23466,20 +24182,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV9formIndex6beforeySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV5index_8offsetByS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -23499,26 +24214,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV5index_8offsetByS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV5index_8offsetBy07limitedE0SiSgSi_S2itF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -23526,7 +24239,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -23546,20 +24260,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV5index_8offsetBy07limitedE0SiSgSi_S2itF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV8distance4from2toS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -23579,81 +24292,147 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV8distance4from2toS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s15ContiguousArrayVyxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ArraySlice",
+              "printedName": "ArraySlice<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:s10ArraySliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s15ContiguousArrayVys0B5SliceVyxGSnySiGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s15ContiguousArrayV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15ContiguousArrayV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s15ContiguousArrayV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ArraySlice",
               "printedName": "ArraySlice<Element>",
-              "usr": "s:s10ArraySliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s10ArraySliceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15ContiguousArrayV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(arrayLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s15ContiguousArrayV12arrayLiteralAByxGxd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ContiguousArray",
               "printedName": "ContiguousArray<Element>",
-              "usr": "s:s15ContiguousArrayV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s15ContiguousArrayV"
             },
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[ContiguousArray<Element>.Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -23667,115 +24446,112 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s15ContiguousArrayV12arrayLiteralAByxGxd_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "ArrayLiteralElement",
           "printedName": "ArrayLiteralElement",
-          "declKind": "TypeAlias",
-          "usr": "s:s15ContiguousArrayV0B14LiteralElementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15ContiguousArrayV0B14LiteralElementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s15ContiguousArrayVAByxGycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ContiguousArray",
               "printedName": "ContiguousArray<Element>",
-              "usr": "s:s15ContiguousArrayV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s15ContiguousArrayV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s15ContiguousArrayVAByxGycfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s15ContiguousArrayVyAByxGqd__c7ElementQyd__RszSTRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ContiguousArray",
               "printedName": "ContiguousArray<Element>",
-              "usr": "s:s15ContiguousArrayV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s15ContiguousArrayV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s15ContiguousArrayVyAByxGqd__c7ElementQyd__RszSTRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(repeating:count:)",
-          "declKind": "Constructor",
-          "usr": "s:s15ContiguousArrayV9repeating5countAByxGx_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ContiguousArray",
               "printedName": "ContiguousArray<Element>",
-              "usr": "s:s15ContiguousArrayV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s15ContiguousArrayV"
             },
             {
               "kind": "TypeNameAlias",
@@ -23795,19 +24571,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s15ContiguousArrayV9repeating5countAByxGx_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s15ContiguousArrayV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -23819,11 +24596,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15ContiguousArrayV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -23831,21 +24603,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15ContiguousArrayV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15ContiguousArrayV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "capacity",
           "printedName": "capacity",
-          "declKind": "Var",
-          "usr": "s:s15ContiguousArrayV8capacitySivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -23857,11 +24632,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15ContiguousArrayV8capacitySivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -23869,24 +24639,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15ContiguousArrayV8capacitySivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15ContiguousArrayV8capacitySivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "reserveCapacity",
           "printedName": "reserveCapacity(_:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV15reserveCapacityyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -23899,22 +24669,21 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV15reserveCapacityyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(_:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV6appendyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -23933,22 +24702,21 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV6appendyyxF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV6append10contentsOfyqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -23960,22 +24728,21 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV6append10contentsOfyqd___t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "remove",
           "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV6remove2atxSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -23995,21 +24762,21 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV6remove2atxSi_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(_:at:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV6insert_2atyx_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -24034,21 +24801,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV6insert_2atyxn_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeAll",
           "printedName": "removeAll(keepingCapacity:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV9removeAll15keepingCapacityySb_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -24062,16 +24828,20 @@
               "hasDefaultArg": true,
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV9removeAll15keepingCapacityySb_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s15ContiguousArrayV12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -24083,11 +24853,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15ContiguousArrayV12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -24095,18 +24860,21 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15ContiguousArrayV12customMirrors0D0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s15ContiguousArrayV12customMirrors0D0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:s15ContiguousArrayV11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -24118,11 +24886,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15ContiguousArrayV11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -24130,18 +24893,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15ContiguousArrayV11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s15ContiguousArrayV11descriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s15ContiguousArrayV16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -24153,11 +24919,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15ContiguousArrayV16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -24165,24 +24926,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15ContiguousArrayV16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s15ContiguousArrayV16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "withUnsafeBufferPointer",
           "printedName": "withUnsafeBufferPointer(_:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV23withUnsafeBufferPointeryqd__qd__SRyxGKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -24193,9 +24951,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafeBufferPointer<ContiguousArray<Element>.Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -24206,13 +24961,11 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafeBufferPointer<ContiguousArray<Element>.Element>)",
-                  "usr": "s:SR",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafeBufferPointer",
                       "printedName": "UnsafeBufferPointer<ContiguousArray<Element>.Element>",
-                      "usr": "s:SR",
                       "children": [
                         {
                           "kind": "TypeNameAlias",
@@ -24226,30 +24979,32 @@
                             }
                           ]
                         }
-                      ]
+                      ],
+                      "usr": "s:SR"
                     }
-                  ]
+                  ],
+                  "usr": "s:SR"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV23withUnsafeBufferPointeryqd__qd__SRyxGKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, R>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "withUnsafeMutableBufferPointer",
           "printedName": "withUnsafeMutableBufferPointer(_:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV30withUnsafeMutableBufferPointeryqd__qd__SryxGzKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inline",
-            "Semantics"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -24260,9 +25015,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(inout UnsafeMutableBufferPointer<ContiguousArray<Element>.Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -24281,24 +25033,28 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV30withUnsafeMutableBufferPointeryqd__qd__SryxGzKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, R>",
+          "declAttributes": [
+            "Rethrows",
+            "Inline",
+            "Semantics"
+          ],
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "replaceSubrange",
           "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV15replaceSubrange_4withySnySiG_qd__t7ElementQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, C where Element == C.Element, C : Collection>",
-          "mutating": true,
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -24309,7 +25065,6 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Int>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -24317,27 +25072,76 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "C"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV15replaceSubrange_4withySnySiG_qd__nt7ElementQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, C where Element == C.Element, C : Collection>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ContiguousArray",
+              "printedName": "ContiguousArray<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:s15ContiguousArrayV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ContiguousArray",
+              "printedName": "ContiguousArray<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:s15ContiguousArrayV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayVsSQRzlE2eeoiySbAByxG_ADtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Equatable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayVsSHRzlE4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -24350,16 +25154,19 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayVsSHRzlE4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s15ContiguousArrayVsSHRzlE9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -24371,11 +25178,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15ContiguousArrayVsSHRzlE9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -24383,25 +25185,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15ContiguousArrayVsSHRzlE9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s15ContiguousArrayVsSHRzlE9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "withUnsafeMutableBytes",
           "printedName": "withUnsafeMutableBytes(_:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV22withUnsafeMutableBytesyqd__qd__SwKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -24412,9 +25212,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafeMutableRawBufferPointer) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -24425,7 +25222,6 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafeMutableRawBufferPointer)",
-                  "usr": "s:Sw",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -24433,26 +25229,30 @@
                       "printedName": "UnsafeMutableRawBufferPointer",
                       "usr": "s:Sw"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sw"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV22withUnsafeMutableBytesyqd__qd__SwKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, R>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "withUnsafeBytes",
           "printedName": "withUnsafeBytes(_:)",
-          "declKind": "Func",
-          "usr": "s:s15ContiguousArrayV15withUnsafeBytesyqd__qd__SWKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -24463,9 +25263,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafeRawBufferPointer) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -24476,7 +25273,6 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafeRawBufferPointer)",
-                  "usr": "s:SW",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -24484,47 +25280,59 @@
                       "printedName": "UnsafeRawBufferPointer",
                       "usr": "s:SW"
                     }
-                  ]
+                  ],
+                  "usr": "s:SW"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s15ContiguousArrayV15withUnsafeBytesyqd__qd__SWKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, R>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s15ContiguousArrayV",
+      "moduleName": "Swift",
+      "genericSig": "<Element>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "_DestructorSafeContainer",
+        "RandomAccessCollection",
+        "MutableCollection",
+        "BidirectionalCollection",
+        "Collection",
+        "Sequence",
+        "ExpressibleByArrayLiteral",
+        "RangeReplaceableCollection",
+        "ArrayProtocol",
+        "CustomReflectable",
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible",
+        "Equatable",
+        "Hashable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "ClosedRange",
       "printedName": "ClosedRange",
-      "declKind": "Struct",
-      "usr": "s:SN",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Bound where Bound : Comparable>",
-      "conformingProtocols": [
-        "RangeExpression",
-        "Sequence",
-        "Collection",
-        "BidirectionalCollection",
-        "RandomAccessCollection",
-        "Equatable",
-        "Hashable",
-        "CustomStringConvertible",
-        "CustomDebugStringConvertible",
-        "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "lowerBound",
           "printedName": "lowerBound",
-          "declKind": "Var",
-          "usr": "s:SN10lowerBoundxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -24535,32 +25343,34 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SN10lowerBoundxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SN10lowerBoundxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Comparable>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SN10lowerBoundxvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Var",
           "name": "upperBound",
           "printedName": "upperBound",
-          "declKind": "Var",
-          "usr": "s:SN10upperBoundxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -24571,49 +25381,47 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SN10upperBoundxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SN10upperBoundxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Comparable>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SN10upperBoundxvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(uncheckedBounds:)",
-          "declKind": "Constructor",
-          "usr": "s:SN15uncheckedBoundsSNyxGx5lower_x5uppert_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ClosedRange",
               "printedName": "ClosedRange<Bound>",
-              "usr": "s:SN",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "usr": "s:SN"
             },
             {
               "kind": "TypeNominal",
@@ -24646,19 +25454,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SN15uncheckedBoundsSNyxGx5lower_x5uppert_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "isEmpty",
           "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:SN7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -24670,11 +25478,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SN7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -24682,55 +25485,56 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SN7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Comparable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SN7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "relative",
           "printedName": "relative(to:)",
-          "declKind": "Func",
-          "usr": "s:SN8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound, C where Bound == C.Index, C : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Bound>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "C"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SN8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound, C where Bound == C.Index, C : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:SN8containsySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -24743,101 +25547,89 @@
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SN8containsySbxF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Bound",
           "printedName": "Bound",
-          "declKind": "TypeAlias",
-          "usr": "s:SN5Bounda",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SN5Bounda",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "IndexingIterator",
               "printedName": "IndexingIterator<ClosedRange<Bound>>",
-              "usr": "s:s16IndexingIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ClosedRange",
                   "printedName": "ClosedRange<Bound>",
-                  "usr": "s:SN",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Bound"
                     }
-                  ]
+                  ],
+                  "usr": "s:SN"
                 }
-              ]
+              ],
+              "usr": "s:s16IndexingIteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
         },
         {
           "kind": "TypeDecl",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "Enum",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "conformingProtocols": [
-            "Comparable",
-            "Equatable",
-            "Hashable"
-          ],
-          "declAttributes": [
-            "Frozen"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "pastEnd",
               "printedName": "pastEnd",
-              "declKind": "EnumElement",
-              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO7pastEndyADyx_GAFmSxRzSZABRQlF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -24872,16 +25664,16 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO7pastEndyADyx_GAFmSxRzSZABRQlF",
+              "moduleName": "Swift",
+              "fixedbinaryorder": 0
             },
             {
               "kind": "Var",
               "name": "inRange",
               "printedName": "inRange",
-              "declKind": "EnumElement",
-              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO7inRangeyADyx_GxcAFmSxRzSZABRQlF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -24935,20 +25727,82 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO7inRangeyADyx_GxcAFmSxRzSZABRQlF",
+              "moduleName": "Swift",
+              "fixedbinaryorder": 1
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ClosedRange<Bound>.Index",
+                  "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ClosedRange<Bound>.Index",
+                  "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO2eeoiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ClosedRange<Bound>.Index",
+                  "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ClosedRange<Bound>.Index",
+                  "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO1loiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexOsSHRzrlE4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Hashable, Bound : Strideable, Bound.Stride : SignedInteger>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -24961,16 +25815,19 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexOsSHRzrlE4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Hashable, Bound : Strideable, Bound.Stride : SignedInteger>",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexOsSHRzrlE9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -24982,11 +25839,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexOsSHRzrlE9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Bound where Bound : Hashable, Bound : Strideable, Bound.Stride : SignedInteger>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -24994,56 +25846,69 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexOsSHRzrlE9hashValueSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Bound where Bound : Hashable, Bound : Strideable, Bound.Stride : SignedInteger>",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexOsSHRzrlE9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Enum",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "declAttributes": [
+            "Frozen"
+          ],
+          "conformingProtocols": [
+            "Comparable",
+            "Equatable",
+            "Hashable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<ClosedRange<Bound>>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ClosedRange",
                   "printedName": "ClosedRange<Bound>",
-                  "usr": "s:SN",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Bound"
                     }
-                  ]
+                  ],
+                  "usr": "s:SN"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE10startIndexSNsSxRzSZABRQrlE0C0Oyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -25055,11 +25920,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SNsSxRzSZ6StrideRpzrlE10startIndexSNsSxRzSZABRQrlE0C0Oyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -25067,21 +25927,24 @@
                   "printedName": "ClosedRange<Bound>.Index",
                   "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE10startIndexSNsSxRzSZABRQrlE0C0Oyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE10startIndexSNsSxRzSZABRQrlE0C0Oyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE8endIndexSNsSxRzSZABRQrlE0C0Oyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -25093,11 +25956,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SNsSxRzSZ6StrideRpzrlE8endIndexSNsSxRzSZABRQrlE0C0Oyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -25105,22 +25963,24 @@
                   "printedName": "ClosedRange<Bound>.Index",
                   "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE8endIndexSNsSxRzSZABRQrlE0C0Oyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE8endIndexSNsSxRzSZABRQrlE0C0Oyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE5index5afterSNsSxRzSZABRQrlE5IndexOyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -25134,20 +25994,19 @@
               "printedName": "ClosedRange<Bound>.Index",
               "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE5index5afterSNsSxRzSZABRQrlE5IndexOyx_GAG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE5index6beforeSNsSxRzSZABRQrlE5IndexOyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -25161,20 +26020,19 @@
               "printedName": "ClosedRange<Bound>.Index",
               "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE5index6beforeSNsSxRzSZABRQrlE5IndexOyx_GAG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE5index_8offsetBySNsSxRzSZABRQrlE5IndexOyx_GAG_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -25194,20 +26052,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE5index_8offsetBySNsSxRzSZABRQrlE5IndexOyx_GAG_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE8distance4from2toSiSNsSxRzSZABRQrlE5IndexOyx_G_AHtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -25227,53 +26084,187 @@
               "printedName": "ClosedRange<Bound>.Index",
               "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE8distance4from2toSiSNsSxRzSZABRQrlE5IndexOyx_G_AHtF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Bound",
+              "printedName": "ClosedRange<Bound>.Bound",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "ClosedRange<Bound>.Index",
+              "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlEyxSNsSxRzSZABRQrlE5IndexOyx_Gcip",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<ClosedRange<ClosedRange<Bound>.Bound>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ClosedRange",
+                  "printedName": "ClosedRange<ClosedRange<Bound>.Bound>",
+                  "children": [
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Bound",
+                      "printedName": "ClosedRange<Bound>.Bound",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
+                        }
+                      ]
+                    }
+                  ],
+                  "usr": "s:SN"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<ClosedRange<Bound>.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ClosedRange<Bound>.Index",
+                  "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlEys5SliceVySNyxGGSnySNsSxRzSZABRQrlE5IndexOyx_GGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlE7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DefaultIndices",
               "printedName": "DefaultIndices<ClosedRange<Bound>>",
-              "usr": "s:SI",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ClosedRange",
                   "printedName": "ClosedRange<Bound>",
-                  "usr": "s:SN",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Bound"
                     }
-                  ]
+                  ],
+                  "usr": "s:SN"
                 }
-              ]
+              ],
+              "usr": "s:SI"
             }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "implicit": true
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<Bound>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Bound"
+                }
+              ],
+              "usr": "s:SN"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<Bound>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Bound"
+                }
+              ],
+              "usr": "s:SN"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SN2eeoiySbSNyxG_ABtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SNsSHRzrlE4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable, Bound : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -25286,16 +26277,19 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SNsSHRzrlE4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable, Bound : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SNsSHRzrlE9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -25307,11 +26301,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SNsSHRzrlE9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable, Bound : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -25319,21 +26308,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SNsSHRzrlE9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Comparable, Bound : Hashable>",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SNsSHRzrlE9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:SN11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -25345,11 +26336,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SN11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -25357,18 +26343,24 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SN11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Comparable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SN11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:SN16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -25380,11 +26372,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SN16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -25392,18 +26379,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SN16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Comparable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SN16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:SN12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -25415,11 +26405,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SN12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -25427,109 +26412,106 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SN12customMirrors0B0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Comparable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SN12customMirrors0B0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "clamped",
           "printedName": "clamped(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<Bound>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Bound"
+                }
+              ],
+              "usr": "s:SN"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<Bound>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Bound"
+                }
+              ],
+              "usr": "s:SN"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SN7clamped2toSNyxGAC_tF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Bound where Bound : Comparable>",
           "declAttributes": [
             "Inline",
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ClosedRange",
-              "printedName": "ClosedRange<Bound>",
-              "usr": "s:SN",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "ClosedRange",
-              "printedName": "ClosedRange<Bound>",
-              "usr": "s:SN",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<Bound>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Bound"
+                }
+              ],
+              "usr": "s:SN"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<ClosedRange<Bound>.Bound>",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Bound",
+                  "printedName": "ClosedRange<Bound>.Bound",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SNsSxRzSZ6StrideRpzrlEySNyxGSnyxGcfc",
-          "location": "",
           "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "ClosedRange",
-              "printedName": "ClosedRange<Bound>",
-              "usr": "s:SN",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<ClosedRange<Bound>.Bound>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Bound",
-                  "printedName": "ClosedRange<Bound>.Bound",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
         },
         {
           "kind": "Function",
           "name": "overlaps",
           "printedName": "overlaps(_:)",
-          "declKind": "Func",
-          "usr": "s:SN8overlapsySbSNyxGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -25541,7 +26523,6 @@
               "kind": "TypeNominal",
               "name": "ClosedRange",
               "printedName": "ClosedRange<ClosedRange<Bound>.Bound>",
-              "usr": "s:SN",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -25555,22 +26536,22 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:SN"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SN8overlapsySbSNyxGF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "overlaps",
           "printedName": "overlaps(_:)",
-          "declKind": "Func",
-          "usr": "s:SN8overlapsySbSnyxGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -25582,7 +26563,6 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<ClosedRange<Bound>.Bound>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -25596,41 +26576,40 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SN8overlapsySbSnyxGF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SNsSxRzSZ6StrideRpzrlEySNyxGACcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ClosedRange",
               "printedName": "ClosedRange<Bound>",
-              "usr": "s:SN",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "usr": "s:SN"
             },
             {
               "kind": "TypeNominal",
               "name": "ClosedRange",
               "printedName": "ClosedRange<ClosedRange<Bound>.Bound>",
-              "usr": "s:SN",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -25644,45 +26623,68 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:SN"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlEySNyxGACcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:SN",
+      "moduleName": "Swift",
+      "genericSig": "<Bound where Bound : Comparable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "RangeExpression",
+        "Sequence",
+        "Collection",
+        "BidirectionalCollection",
+        "RandomAccessCollection",
+        "Equatable",
+        "Hashable",
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible",
+        "CustomReflectable"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "CountableClosedRange",
       "printedName": "CountableClosedRange",
-      "declKind": "TypeAlias",
-      "usr": "s:s20CountableClosedRangea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
       "children": [
         {
           "kind": "TypeNominal",
           "name": "ClosedRange",
           "printedName": "ClosedRange<Bound>",
-          "usr": "s:SN",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
-          ]
+          ],
+          "usr": "s:SN"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s20CountableClosedRangea",
+      "moduleName": "Swift",
+      "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
     },
     {
       "kind": "TypeAlias",
       "name": "CChar",
       "printedName": "CChar",
-      "declKind": "TypeAlias",
-      "usr": "s:s5CChara",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25690,16 +26692,15 @@
           "printedName": "Int8",
           "usr": "s:s4Int8V"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s5CChara",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CUnsignedChar",
       "printedName": "CUnsignedChar",
-      "declKind": "TypeAlias",
-      "usr": "s:s13CUnsignedChara",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25707,16 +26708,15 @@
           "printedName": "UInt8",
           "usr": "s:s5UInt8V"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s13CUnsignedChara",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CUnsignedShort",
       "printedName": "CUnsignedShort",
-      "declKind": "TypeAlias",
-      "usr": "s:s14CUnsignedShorta",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25724,16 +26724,15 @@
           "printedName": "UInt16",
           "usr": "s:s6UInt16V"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s14CUnsignedShorta",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CUnsignedInt",
       "printedName": "CUnsignedInt",
-      "declKind": "TypeAlias",
-      "usr": "s:s12CUnsignedInta",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25741,16 +26740,15 @@
           "printedName": "UInt32",
           "usr": "s:s6UInt32V"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s12CUnsignedInta",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CUnsignedLong",
       "printedName": "CUnsignedLong",
-      "declKind": "TypeAlias",
-      "usr": "s:s13CUnsignedLonga",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25758,16 +26756,15 @@
           "printedName": "UInt",
           "usr": "s:Su"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s13CUnsignedLonga",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CUnsignedLongLong",
       "printedName": "CUnsignedLongLong",
-      "declKind": "TypeAlias",
-      "usr": "s:s013CUnsignedLongB0a",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25775,16 +26772,15 @@
           "printedName": "UInt64",
           "usr": "s:s6UInt64V"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s013CUnsignedLongB0a",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CSignedChar",
       "printedName": "CSignedChar",
-      "declKind": "TypeAlias",
-      "usr": "s:s11CSignedChara",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25792,16 +26788,15 @@
           "printedName": "Int8",
           "usr": "s:s4Int8V"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s11CSignedChara",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CShort",
       "printedName": "CShort",
-      "declKind": "TypeAlias",
-      "usr": "s:s6CShorta",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25809,16 +26804,15 @@
           "printedName": "Int16",
           "usr": "s:s5Int16V"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s6CShorta",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CInt",
       "printedName": "CInt",
-      "declKind": "TypeAlias",
-      "usr": "s:s4CInta",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25826,16 +26820,15 @@
           "printedName": "Int32",
           "usr": "s:s5Int32V"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s4CInta",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CLong",
       "printedName": "CLong",
-      "declKind": "TypeAlias",
-      "usr": "s:s5CLonga",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25843,16 +26836,15 @@
           "printedName": "Int",
           "usr": "s:Si"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s5CLonga",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CLongLong",
       "printedName": "CLongLong",
-      "declKind": "TypeAlias",
-      "usr": "s:s9CLongLonga",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25860,16 +26852,15 @@
           "printedName": "Int64",
           "usr": "s:s5Int64V"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s9CLongLonga",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CFloat",
       "printedName": "CFloat",
-      "declKind": "TypeAlias",
-      "usr": "s:s6CFloata",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25877,16 +26868,15 @@
           "printedName": "Float",
           "usr": "s:Sf"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s6CFloata",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CDouble",
       "printedName": "CDouble",
-      "declKind": "TypeAlias",
-      "usr": "s:s7CDoublea",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25894,16 +26884,15 @@
           "printedName": "Double",
           "usr": "s:Sd"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s7CDoublea",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CLongDouble",
       "printedName": "CLongDouble",
-      "declKind": "TypeAlias",
-      "usr": "s:s11CLongDoublea",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25911,16 +26900,15 @@
           "printedName": "Float80",
           "usr": "s:s7Float80V"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s11CLongDoublea",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CWideChar",
       "printedName": "CWideChar",
-      "declKind": "TypeAlias",
-      "usr": "s:s9CWideChara",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25928,16 +26916,15 @@
           "printedName": "Unicode.Scalar",
           "usr": "s:s7UnicodeO6ScalarV"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s9CWideChara",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CChar16",
       "printedName": "CChar16",
-      "declKind": "TypeAlias",
-      "usr": "s:s7CChar16a",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25945,16 +26932,15 @@
           "printedName": "UInt16",
           "usr": "s:s6UInt16V"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s7CChar16a",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CChar32",
       "printedName": "CChar32",
-      "declKind": "TypeAlias",
-      "usr": "s:s7CChar32a",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25962,16 +26948,15 @@
           "printedName": "Unicode.Scalar",
           "usr": "s:s7UnicodeO6ScalarV"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s7CChar32a",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CBool",
       "printedName": "CBool",
-      "declKind": "TypeAlias",
-      "usr": "s:s5CBoola",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -25979,38 +26964,20 @@
           "printedName": "Bool",
           "usr": "s:Sb"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s5CBoola",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "OpaquePointer",
       "printedName": "OpaquePointer",
-      "declKind": "Struct",
-      "usr": "s:s13OpaquePointerV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable",
-        "CustomDebugStringConvertible",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABBpcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "UsableFromInline"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -26030,25 +26997,25 @@
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABBpcfc",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "Transparent",
+            "UsableFromInline"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerV10bitPatternABSgSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "OpaquePointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26056,7 +27023,8 @@
                   "printedName": "OpaquePointer",
                   "usr": "s:s13OpaquePointerV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -26064,25 +27032,23 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerV10bitPatternABSgSi_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerV10bitPatternABSgSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "OpaquePointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26090,7 +27056,8 @@
                   "printedName": "OpaquePointer",
                   "usr": "s:s13OpaquePointerV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -26098,20 +27065,18 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerV10bitPatternABSgSu_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABSPyxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -26123,35 +27088,33 @@
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<T>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABSPyxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABSgSPyxGSgclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "OpaquePointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26159,43 +27122,43 @@
                   "printedName": "OpaquePointer",
                   "usr": "s:s13OpaquePointerV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafePointer<T>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafePointer",
                   "printedName": "UnsafePointer<T>",
-                  "usr": "s:SP",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "T"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABSgSPyxGSgclufc",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABSpyxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -26207,35 +27170,33 @@
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
               "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABSpyxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABSgSpyxGSgclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "OpaquePointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26243,42 +27204,75 @@
                   "printedName": "OpaquePointer",
                   "usr": "s:s13OpaquePointerV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeMutablePointer<T>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafeMutablePointer",
                   "printedName": "UnsafeMutablePointer<T>",
-                  "usr": "s:Sp",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "T"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABSgSpyxGSgclufc",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "OpaquePointer",
+              "printedName": "OpaquePointer",
+              "usr": "s:s13OpaquePointerV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "OpaquePointer",
+              "printedName": "OpaquePointer",
+              "usr": "s:s13OpaquePointerV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13OpaquePointerV2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s13OpaquePointerV4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -26291,16 +27285,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13OpaquePointerV4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s13OpaquePointerV9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -26312,10 +27308,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13OpaquePointerV9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26323,18 +27315,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13OpaquePointerV9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s13OpaquePointerV9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s13OpaquePointerV16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -26346,10 +27342,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13OpaquePointerV16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26357,21 +27349,20 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13OpaquePointerV16debugDescriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s13OpaquePointerV16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABSvcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -26385,25 +27376,23 @@
               "printedName": "UnsafeMutableRawPointer",
               "usr": "s:Sv"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABSvcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABSgSvSgcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "OpaquePointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26411,13 +27400,13 @@
                   "printedName": "OpaquePointer",
                   "usr": "s:s13OpaquePointerV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeMutableRawPointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26425,21 +27414,21 @@
                   "printedName": "UnsafeMutableRawPointer",
                   "usr": "s:Sv"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABSgSvSgcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABSVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -26453,25 +27442,23 @@
               "printedName": "UnsafeRawPointer",
               "usr": "s:SV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABSVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13OpaquePointerVyABSgSVSgcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "OpaquePointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26479,13 +27466,13 @@
                   "printedName": "OpaquePointer",
                   "usr": "s:s13OpaquePointerV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeRawPointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26493,35 +27480,40 @@
                   "printedName": "UnsafeRawPointer",
                   "usr": "s:SV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13OpaquePointerVyABSgSVSgcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s13OpaquePointerV",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable",
+        "CustomDebugStringConvertible",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "CVaListPointer",
       "printedName": "CVaListPointer",
-      "declKind": "Struct",
-      "usr": "s:s14CVaListPointerV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "CustomDebugStringConvertible"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s14CVaListPointerV16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -26533,10 +27525,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14CVaListPointerV16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26544,47 +27532,36 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14CVaListPointerV16debugDescriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s14CVaListPointerV16debugDescriptionSSvp",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s14CVaListPointerV",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "CustomDebugStringConvertible"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Dictionary",
       "printedName": "Dictionary",
-      "declKind": "Struct",
-      "usr": "s:SD",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Key, Value where Key : Hashable>",
-      "conformingProtocols": [
-        "Encodable",
-        "Decodable",
-        "Sequence",
-        "Collection",
-        "ExpressibleByDictionaryLiteral",
-        "Equatable",
-        "Hashable",
-        "_HasCustomAnyHashableRepresentation",
-        "CustomStringConvertible",
-        "CustomDebugStringConvertible",
-        "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:SD7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -26603,26 +27580,21 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SD7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:S2Dyxq_Gycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Dictionary",
               "printedName": "Dictionary<Key, Value>",
-              "usr": "s:SD",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26634,28 +27606,27 @@
                   "name": "GenericTypeParam",
                   "printedName": "Value"
                 }
-              ]
+              ],
+              "usr": "s:SD"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:S2Dyxq_Gycfc",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(minimumCapacity:)",
-          "declKind": "Constructor",
-          "usr": "s:SD15minimumCapacitySDyxq_GSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Dictionary",
               "printedName": "Dictionary<Key, Value>",
-              "usr": "s:SD",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26667,7 +27638,8 @@
                   "name": "GenericTypeParam",
                   "printedName": "Value"
                 }
-              ]
+              ],
+              "usr": "s:SD"
             },
             {
               "kind": "TypeNominal",
@@ -26675,26 +27647,21 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SD15minimumCapacitySDyxq_GSi_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(uniqueKeysWithValues:)",
-          "declKind": "Constructor",
-          "usr": "s:SD20uniqueKeysWithValuesSDyxq_Gqd___tcSTRd__x_q_t7ElementRtd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value, S where Key : Hashable, S : Sequence, S.Element == (Key, Value)>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Dictionary",
               "printedName": "Dictionary<Key, Value>",
-              "usr": "s:SD",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26706,35 +27673,32 @@
                   "name": "GenericTypeParam",
                   "printedName": "Value"
                 }
-              ]
+              ],
+              "usr": "s:SD"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SD20uniqueKeysWithValuesSDyxq_Gqd__n_tcSTRd__x_q_t7ElementRtd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value, S where Key : Hashable, S : Sequence, S.Element == (Key, Value)>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:uniquingKeysWith:)",
-          "declKind": "Constructor",
-          "usr": "s:SD_16uniquingKeysWithSDyxq_Gqd___q_q__q_tKXEtKcSTRd__x_q_t7ElementRtd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value, S where Key : Hashable, S : Sequence, S.Element == (Key, Value)>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Dictionary",
               "printedName": "Dictionary<Key, Value>",
-              "usr": "s:SD",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26746,7 +27710,8 @@
                   "name": "GenericTypeParam",
                   "printedName": "Value"
                 }
-              ]
+              ],
+              "usr": "s:SD"
             },
             {
               "kind": "TypeNominal",
@@ -26757,9 +27722,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value) throws -> Dictionary<Key, Value>.Value",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -26804,30 +27766,31 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SD_16uniquingKeysWithSDyxq_Gqd__n_q_q__q_tKXEtKcSTRd__x_q_t7ElementRtd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value, S where Key : Hashable, S : Sequence, S.Element == (Key, Value)>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(grouping:by:)",
-          "declKind": "Constructor",
-          "usr": "s:SD8grouping2bySDyxSay7ElementQyd__GGqd___xADKXEtKcAERs_STRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value, S where Key : Hashable, Value == [S.Element], S : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Dictionary",
               "printedName": "Dictionary<Key, Value>",
-              "usr": "s:SD",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26839,7 +27802,8 @@
                   "name": "GenericTypeParam",
                   "printedName": "Value"
                 }
-              ]
+              ],
+              "usr": "s:SD"
             },
             {
               "kind": "TypeNominal",
@@ -26850,9 +27814,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(S.Element) throws -> Dictionary<Key, Value>.Key",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -26878,23 +27839,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SD8grouping2bySDyxSay7ElementQyd__GGqd__n_xADKXEtKcAERs_STRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value, S where Key : Hashable, Value == [S.Element], S : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:SDsSERzSER_rlE6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Encodable, Key : Hashable, Value : Encodable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -26907,27 +27871,22 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SDsSERzSER_rlE6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Encodable, Key : Hashable, Value : Encodable>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:SDsSeRzSeR_rlE4fromSDyxq_Gs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Decodable, Key : Hashable, Value : Decodable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Dictionary",
               "printedName": "Dictionary<Key, Value>",
-              "usr": "s:SD",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -26939,7 +27898,8 @@
                   "name": "GenericTypeParam",
                   "printedName": "Value"
                 }
-              ]
+              ],
+              "usr": "s:SD"
             },
             {
               "kind": "TypeNominal",
@@ -26947,2618 +27907,75 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SDsSeRzSeR_rlE4fromSDyxq_Gs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Decodable, Key : Hashable, Value : Decodable>",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Iterator",
+              "printedName": "Dictionary<Key, Value>.Iterator",
+              "usr": "s:SD8IteratorV"
+            }
+          ],
           "declKind": "Func",
-          "usr": "s:SD12makeIterators010DictionaryB0Vyxq_GyF",
-          "location": "",
+          "usr": "s:SD12makeIteratorSD0B0Vyxq__GyF",
           "moduleName": "Swift",
           "genericSig": "<Key, Value where Key : Hashable>",
           "declAttributes": [
             "Inline",
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DictionaryIterator",
-              "printedName": "DictionaryIterator<Dictionary<Key, Value>.Key, Dictionary<Key, Value>.Value>",
-              "usr": "s:s18DictionaryIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Key",
-                  "printedName": "Dictionary<Key, Value>.Key",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:SD10startIndexSD0B0Vyxq__Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "Dictionary<Key, Value>.Index",
-              "usr": "s:SD5IndexV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD10startIndexSD0B0Vyxq__Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:SD8endIndexSD0B0Vyxq__Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "Dictionary<Key, Value>.Index",
-              "usr": "s:SD5IndexV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD8endIndexSD0B0Vyxq__Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:SD5index5afterSD5IndexVyxq__GAE_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "Dictionary<Key, Value>.Index",
-              "usr": "s:SD5IndexV"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "Dictionary<Key, Value>.Index",
-              "usr": "s:SD5IndexV"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(forKey:)",
-          "declKind": "Func",
-          "usr": "s:SD5index6forKeySD5IndexVyxq__GSgx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Dictionary<Key, Value>.Index?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "Dictionary<Key, Value>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "count",
-          "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:SD5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isEmpty",
-          "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:SD7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:SD8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DictionaryIterator",
-              "printedName": "DictionaryIterator<Key, Value>",
-              "usr": "s:s18DictionaryIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Key"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:SD11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<Dictionary<Key, Value>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Dictionary",
-                  "printedName": "Dictionary<Key, Value>",
-                  "usr": "s:SD",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:SD7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DefaultIndices",
-              "printedName": "DefaultIndices<Dictionary<Key, Value>>",
-              "usr": "s:SI",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Dictionary",
-                  "printedName": "Dictionary<Key, Value>",
-                  "usr": "s:SD",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(dictionaryLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:SD17dictionaryLiteralSDyxq_Gx_q_td_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "declAttributes": [
-            "Effects",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Dictionary",
-              "printedName": "Dictionary<Key, Value>",
-              "usr": "s:SD",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Key"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "[(Key, Value)]",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(Key, Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Key",
-          "printedName": "Key",
-          "declKind": "TypeAlias",
-          "usr": "s:SD3Keya",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Key"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Value",
-          "printedName": "Value",
-          "declKind": "TypeAlias",
-          "usr": "s:SD5Valuea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Value"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "mapValues",
-          "printedName": "mapValues(_:)",
-          "declKind": "Func",
-          "usr": "s:SD9mapValuesySDyxqd__Gqd__q_KXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value, T where Key : Hashable>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Dictionary",
-              "printedName": "Dictionary<Dictionary<Key, Value>.Key, T>",
-              "usr": "s:SD",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Key",
-                  "printedName": "Dictionary<Key, Value>.Key",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Dictionary<Key, Value>.Value) throws -> T",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Dictionary<Key, Value>.Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "compactMapValues",
-          "printedName": "compactMapValues(_:)",
-          "declKind": "Func",
-          "usr": "s:SD16compactMapValuesySDyxqd__Gqd__Sgq_KXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value, T where Key : Hashable>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Dictionary",
-              "printedName": "Dictionary<Dictionary<Key, Value>.Key, T>",
-              "usr": "s:SD",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Key",
-                  "printedName": "Dictionary<Key, Value>.Key",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "T"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Dictionary<Key, Value>.Value) throws -> T?",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "T?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "T"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Dictionary<Key, Value>.Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "updateValue",
-          "printedName": "updateValue(_:forKey:)",
-          "declKind": "Func",
-          "usr": "s:SD11updateValue_6forKeyq_Sgq__xtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Dictionary<Key, Value>.Value?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Value",
-              "printedName": "Dictionary<Key, Value>.Value",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_1"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "Dictionary<Key, Value>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "merge",
-          "printedName": "merge(_:uniquingKeysWith:)",
-          "declKind": "Func",
-          "usr": "s:SD5merge_16uniquingKeysWithyqd___q_q__q_tKXEtKSTRd__x_q_t7ElementRtd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value, S where Key : Hashable, S : Sequence, S.Element == (Key, Value)>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value) throws -> Dictionary<Key, Value>.Value",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "merge",
-          "printedName": "merge(_:uniquingKeysWith:)",
-          "declKind": "Func",
-          "usr": "s:SD5merge_16uniquingKeysWithySDyxq_G_q_q__q_tKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Dictionary",
-              "printedName": "[Dictionary<Key, Value>.Key : Dictionary<Key, Value>.Value]",
-              "usr": "s:SD",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Key",
-                  "printedName": "Dictionary<Key, Value>.Key",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value) throws -> Dictionary<Key, Value>.Value",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "merging",
-          "printedName": "merging(_:uniquingKeysWith:)",
-          "declKind": "Func",
-          "usr": "s:SD7merging_16uniquingKeysWithSDyxq_Gqd___q_q__q_tKXEtKSTRd__x_q_t7ElementRtd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value, S where Key : Hashable, S : Sequence, S.Element == (Key, Value)>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Dictionary",
-              "printedName": "[Dictionary<Key, Value>.Key : Dictionary<Key, Value>.Value]",
-              "usr": "s:SD",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Key",
-                  "printedName": "Dictionary<Key, Value>.Key",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value) throws -> Dictionary<Key, Value>.Value",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "merging",
-          "printedName": "merging(_:uniquingKeysWith:)",
-          "declKind": "Func",
-          "usr": "s:SD7merging_16uniquingKeysWithSDyxq_GAC_q_q__q_tKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Dictionary",
-              "printedName": "[Dictionary<Key, Value>.Key : Dictionary<Key, Value>.Value]",
-              "usr": "s:SD",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Key",
-                  "printedName": "Dictionary<Key, Value>.Key",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Dictionary",
-              "printedName": "[Dictionary<Key, Value>.Key : Dictionary<Key, Value>.Value]",
-              "usr": "s:SD",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Key",
-                  "printedName": "Dictionary<Key, Value>.Key",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value) throws -> Dictionary<Key, Value>.Value",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Value",
-                      "printedName": "Dictionary<Key, Value>.Value",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "remove",
-          "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:SD6remove2atx3key_q_5valuetSD5IndexVyxq__G_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Element",
-              "printedName": "Dictionary<Key, Value>.Element",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(key: τ_0_0, value: τ_0_1)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Index",
-              "printedName": "Dictionary<Key, Value>.Index",
-              "usr": "s:SD5IndexV"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "removeValue",
-          "printedName": "removeValue(forKey:)",
-          "declKind": "Func",
-          "usr": "s:SD11removeValue6forKeyq_Sgx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Dictionary<Key, Value>.Value?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Value",
-                  "printedName": "Dictionary<Key, Value>.Value",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_1"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Key",
-              "printedName": "Dictionary<Key, Value>.Key",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "τ_0_0"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "removeAll",
-          "printedName": "removeAll(keepingCapacity:)",
-          "declKind": "Func",
-          "usr": "s:SD9removeAll15keepingCapacityySb_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "hasDefaultArg": true,
-              "usr": "s:Sb"
-            }
-          ]
-        },
-        {
-          "kind": "TypeDecl",
-          "name": "Keys",
-          "printedName": "Keys",
-          "declKind": "Struct",
-          "usr": "s:SD4KeysV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "conformingProtocols": [
-            "Collection",
-            "Equatable",
-            "CustomStringConvertible",
-            "CustomDebugStringConvertible",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:SD4KeysV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Key"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "startIndex",
-              "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:SD4KeysV10startIndexSD0C0Vyxq__Gvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD4KeysV10startIndexSD0C0Vyxq__Gvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "Dictionary<Key, Value>.Index",
-                      "usr": "s:SD5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "endIndex",
-              "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:SD4KeysV8endIndexSD0C0Vyxq__Gvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD4KeysV8endIndexSD0C0Vyxq__Gvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "Dictionary<Key, Value>.Index",
-                      "usr": "s:SD5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SD4KeysV5index5afterSD5IndexVyxq__GAG_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "count",
-              "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:SD4KeysV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD4KeysV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "isEmpty",
-              "printedName": "isEmpty",
-              "declKind": "Var",
-              "usr": "s:SD4KeysV7isEmptySbvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD4KeysV7isEmptySbvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Bool",
-                      "printedName": "Bool",
-                      "usr": "s:Sb"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "description",
-              "printedName": "description",
-              "declKind": "Var",
-              "usr": "s:SD4KeysV11descriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD4KeysV11descriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "String",
-                      "printedName": "String",
-                      "usr": "s:SS"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "debugDescription",
-              "printedName": "debugDescription",
-              "declKind": "Var",
-              "usr": "s:SD4KeysV16debugDescriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD4KeysV16debugDescriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "String",
-                      "printedName": "String",
-                      "usr": "s:SS"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:SD4KeysV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:SD4KeysV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<Dictionary<Key, Value>.Keys>",
-                  "usr": "s:s16IndexingIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Keys",
-                      "printedName": "Dictionary<Key, Value>.Keys",
-                      "usr": "s:SD4KeysV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:SD4KeysV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Slice",
-                  "printedName": "Slice<Dictionary<Key, Value>.Keys>",
-                  "usr": "s:s5SliceV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Keys",
-                      "printedName": "Dictionary<Key, Value>.Keys",
-                      "usr": "s:SD4KeysV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:SD4KeysV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DefaultIndices",
-                  "printedName": "DefaultIndices<Dictionary<Key, Value>.Keys>",
-                  "usr": "s:SI",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Keys",
-                      "printedName": "Dictionary<Key, Value>.Keys",
-                      "usr": "s:SD4KeysV"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeDecl",
-          "name": "Values",
-          "printedName": "Values",
-          "declKind": "Struct",
-          "usr": "s:SD6ValuesV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "conformingProtocols": [
-            "MutableCollection",
-            "CustomStringConvertible",
-            "CustomDebugStringConvertible",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "TypeAlias",
-              "name": "Element",
-              "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:SD6ValuesV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "startIndex",
-              "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:SD6ValuesV10startIndexSD0C0Vyxq__Gvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD6ValuesV10startIndexSD0C0Vyxq__Gvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "Dictionary<Key, Value>.Index",
-                      "usr": "s:SD5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "endIndex",
-              "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:SD6ValuesV8endIndexSD0C0Vyxq__Gvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD6ValuesV8endIndexSD0C0Vyxq__Gvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "Dictionary<Key, Value>.Index",
-                      "usr": "s:SD5IndexV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SD6ValuesV5index5afterSD5IndexVyxq__GAG_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "count",
-              "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:SD6ValuesV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD6ValuesV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "isEmpty",
-              "printedName": "isEmpty",
-              "declKind": "Var",
-              "usr": "s:SD6ValuesV7isEmptySbvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD6ValuesV7isEmptySbvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Bool",
-                      "printedName": "Bool",
-                      "usr": "s:Sb"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "description",
-              "printedName": "description",
-              "declKind": "Var",
-              "usr": "s:SD6ValuesV11descriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD6ValuesV11descriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "String",
-                      "printedName": "String",
-                      "usr": "s:SS"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Var",
-              "name": "debugDescription",
-              "printedName": "debugDescription",
-              "declKind": "Var",
-              "usr": "s:SD6ValuesV16debugDescriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD6ValuesV16debugDescriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "String",
-                      "printedName": "String",
-                      "usr": "s:SS"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Index",
-              "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:SD6ValuesV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Index",
-                  "printedName": "Dictionary<Key, Value>.Index",
-                  "usr": "s:SD5IndexV"
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "SubSequence",
-              "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:SD6ValuesV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Slice",
-                  "printedName": "Slice<Dictionary<Key, Value>.Values>",
-                  "usr": "s:s5SliceV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Values",
-                      "printedName": "Dictionary<Key, Value>.Values",
-                      "usr": "s:SD6ValuesV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Iterator",
-              "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:SD6ValuesV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "IndexingIterator",
-                  "printedName": "IndexingIterator<Dictionary<Key, Value>.Values>",
-                  "usr": "s:s16IndexingIteratorV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Values",
-                      "printedName": "Dictionary<Key, Value>.Values",
-                      "usr": "s:SD6ValuesV"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeAlias",
-              "name": "Indices",
-              "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:SD6ValuesV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DefaultIndices",
-                  "printedName": "DefaultIndices<Dictionary<Key, Value>.Values>",
-                  "usr": "s:SI",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Values",
-                      "printedName": "Dictionary<Key, Value>.Values",
-                      "usr": "s:SD6ValuesV"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "hash",
-          "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SDsSHR_rlE4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable, Value : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Hasher",
-              "printedName": "Hasher",
-              "usr": "s:s6HasherV"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "hashValue",
-          "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SDsSHR_rlE9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SDsSHR_rlE9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable, Value : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "description",
-          "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:SD11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "debugDescription",
-          "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:SD16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeDecl",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "Struct",
-          "usr": "s:SD5IndexV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "conformingProtocols": [
-            "Comparable",
-            "Hashable",
-            "Equatable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
-          "children": [
-            {
-              "kind": "Var",
-              "name": "hashValue",
-              "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:SD5IndexV9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SD5IndexV9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Key, Value where Key : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "hash",
-              "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:SD5IndexV4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "declAttributes": [
-                "Inlinable"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Void",
-                  "printedName": "()"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Hasher",
-                  "printedName": "Hasher",
-                  "usr": "s:s6HasherV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:SD12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "popFirst",
-          "printedName": "popFirst()",
-          "declKind": "Func",
-          "usr": "s:SD8popFirstx3key_q_5valuetSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Dictionary<Key, Value>.Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Dictionary<Key, Value>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Tuple",
-                      "printedName": "(key: τ_0_0, value: τ_0_1)",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_0"
-                        },
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "capacity",
-          "printedName": "capacity",
-          "declKind": "Var",
-          "usr": "s:SD8capacitySivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD8capacitySivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "reserveCapacity",
-          "printedName": "reserveCapacity(_:)",
-          "declKind": "Func",
-          "usr": "s:SD15reserveCapacityyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "keys",
-          "printedName": "keys",
-          "declKind": "Var",
-          "usr": "s:SD4keyss17LazyMapCollectionVySDyxq_GxGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyMapCollection",
-              "printedName": "LazyMapCollection<[Key : Value], Key>",
-              "usr": "s:s17LazyMapCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Dictionary",
-                  "printedName": "[Key : Value]",
-                  "usr": "s:SD",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Key"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD4keyss17LazyMapCollectionVySDyxq_GxGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "LazyMapCollection",
-                  "printedName": "LazyMapCollection<[Key : Value], Key>",
-                  "usr": "s:s17LazyMapCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Dictionary",
-                      "printedName": "[Key : Value]",
-                      "usr": "s:SD",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Key"
-                        },
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Value"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "values",
-          "printedName": "values",
-          "declKind": "Var",
-          "usr": "s:SD6valuess17LazyMapCollectionVySDyxq_Gq_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "LazyMapCollection",
-              "printedName": "LazyMapCollection<[Key : Value], Value>",
-              "usr": "s:s17LazyMapCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Dictionary",
-                  "printedName": "[Key : Value]",
-                  "usr": "s:SD",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SD6valuess17LazyMapCollectionVySDyxq_Gq_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "LazyMapCollection",
-                  "printedName": "LazyMapCollection<[Key : Value], Value>",
-                  "usr": "s:s17LazyMapCollectionV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Dictionary",
-                      "printedName": "[Key : Value]",
-                      "usr": "s:SD",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Key"
-                        },
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "Value"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                }
-              ]
-            }
           ]
         },
         {
           "kind": "Function",
           "name": "filter",
-          "printedName": "filter(_:obsoletedInSwift4:)",
-          "declKind": "Func",
-          "usr": "s:SD6filter_17obsoletedInSwift4Sayx3key_q_5valuetGSbxAC_q_ADt_tKXE_yttKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Available"
-          ],
+          "printedName": "filter(_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "[Dictionary<Key, Value>.Element]",
-              "usr": "s:Sa",
+              "name": "Dictionary",
+              "printedName": "[Dictionary<Key, Value>.Key : Dictionary<Key, Value>.Value]",
               "children": [
                 {
                   "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Dictionary<Key, Value>.Element",
+                  "name": "Key",
+                  "printedName": "Dictionary<Key, Value>.Key",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Tuple",
-                      "printedName": "(key: τ_0_0, value: τ_0_1)",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_0"
-                        },
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_1"
-                        }
-                      ]
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Value",
+                  "printedName": "Dictionary<Key, Value>.Value",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:SD"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Dictionary<Key, Value>.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -29597,73 +28014,312 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD6filterySDyxq_GSbx3key_q_5valuet_tKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "Rethrows",
+            "Available",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Dictionary<Key, Value>.Index",
+              "usr": "s:SD5IndexV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD10startIndexSD0B0Vyxq__Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD10startIndexSD0B0Vyxq__Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Dictionary<Key, Value>.Index",
+              "usr": "s:SD5IndexV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD8endIndexSD0B0Vyxq__Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD8endIndexSD0B0Vyxq__Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Dictionary<Key, Value>.Index",
+              "usr": "s:SD5IndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Dictionary<Key, Value>.Index",
+              "usr": "s:SD5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD5index5afterSD5IndexVyxq__GAE_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Dictionary<Key, Value>.Index",
+              "usr": "s:SD5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD9formIndex5afterySD0B0Vyxq__Gz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(forKey:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Dictionary<Key, Value>.Index?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Key",
+              "printedName": "Dictionary<Key, Value>.Key",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD5index6forKeySD5IndexVyxq__GSgx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Element",
+              "printedName": "Dictionary<Key, Value>.Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(key: τ_0_0, value: τ_0_1)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                }
               ]
             },
             {
               "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()",
-              "hasDefaultArg": true
+              "name": "Index",
+              "printedName": "Dictionary<Key, Value>.Index",
+              "usr": "s:SD5IndexV"
             }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "DictionaryIndex",
-      "printedName": "DictionaryIndex",
-      "declKind": "TypeAlias",
-      "usr": "s:s15DictionaryIndexa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Key, Value where Key : Hashable>",
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Index",
-          "printedName": "Dictionary<Key, Value>.Index",
-          "usr": "s:SD5IndexV"
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "DictionaryIterator",
-      "printedName": "DictionaryIterator",
-      "declKind": "Struct",
-      "usr": "s:s18DictionaryIteratorV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Key, Value where Key : Hashable>",
-      "conformingProtocols": [
-        "IteratorProtocol",
-        "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Function",
-          "name": "next",
-          "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s18DictionaryIteratorV4nextx3key_q_5valuetSgyF",
-          "location": "",
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SDyx3key_q_5valuetSD5IndexVyxq__Gcip",
           "moduleName": "Swift",
           "genericSig": "<Key, Value where Key : Hashable>",
-          "mutating": true,
           "declAttributes": [
-            "Inline",
             "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "count",
+          "printedName": "count",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>"
+            }
           ],
+          "declKind": "Var",
+          "usr": "s:SD5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "isEmpty",
+          "printedName": "isEmpty",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "first",
+          "printedName": "first",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "(key: Key, value: Value)?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -29682,24 +28338,185 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "(key: Key, value: Value)?",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Tuple",
+                      "printedName": "(key: Key, value: Value)",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "Key"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "Value"
+                        }
+                      ]
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD5firstx3key_q_5valuetSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD5firstx3key_q_5valuetSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s18DictionaryIteratorV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value where Key : Hashable>",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(key: Key, value: Value)",
+              "name": "Slice",
+              "printedName": "Slice<Dictionary<Key, Value>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Dictionary",
+                  "printedName": "Dictionary<Key, Value>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Key"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Value"
+                    }
+                  ],
+                  "usr": "s:SD"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SD11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "implicit": true
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "Indices",
+          "printedName": "Indices",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DefaultIndices",
+              "printedName": "DefaultIndices<Dictionary<Key, Value>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Dictionary",
+                  "printedName": "Dictionary<Key, Value>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Key"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Value"
+                    }
+                  ],
+                  "usr": "s:SD"
+                }
+              ],
+              "usr": "s:SI"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SD7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "implicit": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Dictionary<Key, Value>.Value?",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Value",
+                  "printedName": "Dictionary<Key, Value>.Value",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Key",
+              "printedName": "Dictionary<Key, Value>.Key",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SDyq_Sgxcip",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(dictionaryLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "Dictionary<Key, Value>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -29711,18 +28528,2544 @@
                   "name": "GenericTypeParam",
                   "printedName": "Value"
                 }
+              ],
+              "usr": "s:SD"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "[(Key, Value)]",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(Key, Value)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Key"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Value"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sa"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SD17dictionaryLiteralSDyxq_Gx_q_td_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "Effects",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "Key",
+          "printedName": "Key",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Key"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SD3Keya",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "implicit": true
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "Value",
+          "printedName": "Value",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Value"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SD5Valuea",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "implicit": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:default:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Value",
+              "printedName": "Dictionary<Key, Value>.Value",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Key",
+              "printedName": "Dictionary<Key, Value>.Key",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "() -> Dictionary<Key, Value>.Value",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Value",
+                  "printedName": "Dictionary<Key, Value>.Value",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SD_7defaultq_x_q_yXKtcip",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Function",
+          "name": "mapValues",
+          "printedName": "mapValues(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "Dictionary<Dictionary<Key, Value>.Key, T>",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Key",
+                  "printedName": "Dictionary<Key, Value>.Key",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "T"
+                }
+              ],
+              "usr": "s:SD"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(Dictionary<Key, Value>.Value) throws -> T",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "T"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Paren",
+                  "printedName": "(Dictionary<Key, Value>.Value)",
+                  "children": [
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Value",
+                      "printedName": "Dictionary<Key, Value>.Value",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_1"
+                        }
+                      ]
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD9mapValuesySDyxqd__Gqd__q_KXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value, T where Key : Hashable>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "compactMapValues",
+          "printedName": "compactMapValues(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "Dictionary<Dictionary<Key, Value>.Key, T>",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Key",
+                  "printedName": "Dictionary<Key, Value>.Key",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "T"
+                }
+              ],
+              "usr": "s:SD"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(Dictionary<Key, Value>.Value) throws -> T?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "T?",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "T"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Paren",
+                  "printedName": "(Dictionary<Key, Value>.Value)",
+                  "children": [
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Value",
+                      "printedName": "Dictionary<Key, Value>.Value",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_1"
+                        }
+                      ]
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD16compactMapValuesySDyxqd__Gqd__Sgq_KXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value, T where Key : Hashable>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "updateValue",
+          "printedName": "updateValue(_:forKey:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Dictionary<Key, Value>.Value?",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Value",
+                  "printedName": "Dictionary<Key, Value>.Value",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Value",
+              "printedName": "Dictionary<Key, Value>.Value",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_1"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Key",
+              "printedName": "Dictionary<Key, Value>.Key",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD11updateValue_6forKeyq_Sgq_n_xtF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "merge",
+          "printedName": "merge(_:uniquingKeysWith:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "S"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value) throws -> Dictionary<Key, Value>.Value",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Value",
+                  "printedName": "Dictionary<Key, Value>.Value",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value)",
+                  "children": [
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Value",
+                      "printedName": "Dictionary<Key, Value>.Value",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_1"
+                        }
+                      ]
+                    },
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Value",
+                      "printedName": "Dictionary<Key, Value>.Value",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_1"
+                        }
+                      ]
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD5merge_16uniquingKeysWithyqd__n_q_q__q_tKXEtKSTRd__x_q_t7ElementRtd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value, S where Key : Hashable, S : Sequence, S.Element == (Key, Value)>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "merge",
+          "printedName": "merge(_:uniquingKeysWith:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "[Dictionary<Key, Value>.Key : Dictionary<Key, Value>.Value]",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Key",
+                  "printedName": "Dictionary<Key, Value>.Key",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Value",
+                  "printedName": "Dictionary<Key, Value>.Value",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:SD"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value) throws -> Dictionary<Key, Value>.Value",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Value",
+                  "printedName": "Dictionary<Key, Value>.Value",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value)",
+                  "children": [
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Value",
+                      "printedName": "Dictionary<Key, Value>.Value",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_1"
+                        }
+                      ]
+                    },
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Value",
+                      "printedName": "Dictionary<Key, Value>.Value",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_1"
+                        }
+                      ]
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD5merge_16uniquingKeysWithySDyxq_Gn_q_q__q_tKXEtKF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "merging",
+          "printedName": "merging(_:uniquingKeysWith:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "[Dictionary<Key, Value>.Key : Dictionary<Key, Value>.Value]",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Key",
+                  "printedName": "Dictionary<Key, Value>.Key",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Value",
+                  "printedName": "Dictionary<Key, Value>.Value",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:SD"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "S"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value) throws -> Dictionary<Key, Value>.Value",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Value",
+                  "printedName": "Dictionary<Key, Value>.Value",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value)",
+                  "children": [
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Value",
+                      "printedName": "Dictionary<Key, Value>.Value",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_1"
+                        }
+                      ]
+                    },
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Value",
+                      "printedName": "Dictionary<Key, Value>.Value",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_1"
+                        }
+                      ]
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD7merging_16uniquingKeysWithSDyxq_Gqd__n_q_q__q_tKXEtKSTRd__x_q_t7ElementRtd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value, S where Key : Hashable, S : Sequence, S.Element == (Key, Value)>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "merging",
+          "printedName": "merging(_:uniquingKeysWith:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "[Dictionary<Key, Value>.Key : Dictionary<Key, Value>.Value]",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Key",
+                  "printedName": "Dictionary<Key, Value>.Key",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Value",
+                  "printedName": "Dictionary<Key, Value>.Value",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:SD"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "[Dictionary<Key, Value>.Key : Dictionary<Key, Value>.Value]",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Key",
+                  "printedName": "Dictionary<Key, Value>.Key",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Value",
+                  "printedName": "Dictionary<Key, Value>.Value",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:SD"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value) throws -> Dictionary<Key, Value>.Value",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Value",
+                  "printedName": "Dictionary<Key, Value>.Value",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(Dictionary<Key, Value>.Value, Dictionary<Key, Value>.Value)",
+                  "children": [
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Value",
+                      "printedName": "Dictionary<Key, Value>.Value",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_1"
+                        }
+                      ]
+                    },
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Value",
+                      "printedName": "Dictionary<Key, Value>.Value",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_1"
+                        }
+                      ]
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD7merging_16uniquingKeysWithSDyxq_GACn_q_q__q_tKXEtKF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "remove",
+          "printedName": "remove(at:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Element",
+              "printedName": "Dictionary<Key, Value>.Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(key: τ_0_0, value: τ_0_1)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Dictionary<Key, Value>.Index",
+              "usr": "s:SD5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD6remove2atx3key_q_5valuetSD5IndexVyxq__G_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "removeValue",
+          "printedName": "removeValue(forKey:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Dictionary<Key, Value>.Value?",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Value",
+                  "printedName": "Dictionary<Key, Value>.Value",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Key",
+              "printedName": "Dictionary<Key, Value>.Key",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD11removeValue6forKeyq_Sgx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "removeAll",
+          "printedName": "removeAll(keepingCapacity:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "hasDefaultArg": true,
+              "usr": "s:Sb"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD9removeAll15keepingCapacityySb_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Var",
+          "name": "keys",
+          "printedName": "keys",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Keys",
+              "printedName": "Dictionary<Key, Value>.Keys",
+              "usr": "s:SD4KeysV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Keys",
+                  "printedName": "Dictionary<Key, Value>.Keys",
+                  "usr": "s:SD4KeysV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD4keysSD4KeysVyxq__Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD4keysSD4KeysVyxq__Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Available",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "values",
+          "printedName": "values",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Values",
+              "printedName": "Dictionary<Key, Value>.Values",
+              "usr": "s:SD6ValuesV"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Values",
+                  "printedName": "Dictionary<Key, Value>.Values",
+                  "usr": "s:SD6ValuesV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD6valuesSD6ValuesVyxq__Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>"
+            },
+            {
+              "kind": "Setter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Values",
+                  "printedName": "Dictionary<Key, Value>.Values",
+                  "usr": "s:SD6ValuesV"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD6valuesSD6ValuesVyxq__Gvs",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD6valuesSD6ValuesVyxq__Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Available",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "Keys",
+          "printedName": "Keys",
+          "children": [
+            {
+              "kind": "TypeAlias",
+              "name": "Element",
+              "printedName": "Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Key"
+                }
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SD4KeysV7Elementa",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>"
+            },
+            {
+              "kind": "Var",
+              "name": "startIndex",
+              "printedName": "startIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Dictionary<Key, Value>.Index",
+                      "usr": "s:SD5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD4KeysV10startIndexSD0C0Vyxq__Gvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD4KeysV10startIndexSD0C0Vyxq__Gvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "endIndex",
+              "printedName": "endIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Dictionary<Key, Value>.Index",
+                      "usr": "s:SD5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD4KeysV8endIndexSD0C0Vyxq__Gvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD4KeysV8endIndexSD0C0Vyxq__Gvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD4KeysV5index5afterSD5IndexVyxq__GAG_tF",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "formIndex",
+              "printedName": "formIndex(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD4KeysV9formIndex5afterySD0C0Vyxq__Gz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Element",
+                  "printedName": "Dictionary<Key, Value>.Keys.Element",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SD4KeysVyxSD5IndexVyxq__Gcip",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "count",
+              "printedName": "count",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD4KeysV5countSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD4KeysV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "isEmpty",
+              "printedName": "isEmpty",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD4KeysV7isEmptySbvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD4KeysV7isEmptySbvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Keys",
+                  "printedName": "Dictionary<Key, Value>.Keys",
+                  "usr": "s:SD4KeysV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Keys",
+                  "printedName": "Dictionary<Key, Value>.Keys",
+                  "usr": "s:SD4KeysV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD4KeysV2eeoiySbAByxq__G_ADtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "description",
+              "printedName": "description",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "String",
+                      "printedName": "String",
+                      "usr": "s:SS"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD4KeysV11descriptionSSvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD4KeysV11descriptionSSvp",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Var",
+              "name": "debugDescription",
+              "printedName": "debugDescription",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "String",
+                      "printedName": "String",
+                      "usr": "s:SS"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD4KeysV16debugDescriptionSSvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD4KeysV16debugDescriptionSSvp",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "TypeAlias",
+              "name": "Index",
+              "printedName": "Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SD4KeysV5Indexa",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "implicit": true
+            },
+            {
+              "kind": "TypeAlias",
+              "name": "SubSequence",
+              "printedName": "SubSequence",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Slice",
+                  "printedName": "Slice<Dictionary<Key, Value>.Keys>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Keys",
+                      "printedName": "Dictionary<Key, Value>.Keys",
+                      "usr": "s:SD4KeysV"
+                    }
+                  ],
+                  "usr": "s:s5SliceV"
+                }
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SD4KeysV11SubSequencea",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "implicit": true
+            },
+            {
+              "kind": "TypeAlias",
+              "name": "Indices",
+              "printedName": "Indices",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DefaultIndices",
+                  "printedName": "DefaultIndices<Dictionary<Key, Value>.Keys>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Keys",
+                      "printedName": "Dictionary<Key, Value>.Keys",
+                      "usr": "s:SD4KeysV"
+                    }
+                  ],
+                  "usr": "s:SI"
+                }
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SD4KeysV7Indicesa",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "implicit": true
+            },
+            {
+              "kind": "TypeDecl",
+              "name": "Iterator",
+              "printedName": "Iterator",
+              "children": [
+                {
+                  "kind": "Constructor",
+                  "name": "init",
+                  "printedName": "init(_:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Iterator",
+                      "printedName": "Dictionary<Key, Value>.Keys.Iterator",
+                      "usr": "s:SD4KeysV8IteratorV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Iterator",
+                      "printedName": "Dictionary<Key, Value>.Iterator",
+                      "usr": "s:SD8IteratorV"
+                    }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:SD4KeysV8IteratorVyADyxq___GSDACVyxq__Gcfc",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "next",
+                  "printedName": "next()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Key?",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "Key"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SD4KeysV8IteratorV4nextxSgyF",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>",
+                  "declAttributes": [
+                    "Inlinable"
+                  ],
+                  "mutating": true
+                },
+                {
+                  "kind": "TypeAlias",
+                  "name": "Element",
+                  "printedName": "Element",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Key"
+                    }
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:SD4KeysV8IteratorV7Elementa",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>",
+                  "implicit": true
+                }
+              ],
+              "declKind": "Struct",
+              "usr": "s:SD4KeysV8IteratorV",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "IteratorProtocol"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "makeIterator",
+              "printedName": "makeIterator()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Iterator",
+                  "printedName": "Dictionary<Key, Value>.Keys.Iterator",
+                  "usr": "s:SD4KeysV8IteratorV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD4KeysV12makeIteratorAB0C0Vyxq___GyF",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SD4KeysV",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "Collection",
+            "Equatable",
+            "CustomStringConvertible",
+            "CustomDebugStringConvertible",
+            "Sequence"
+          ]
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "Values",
+          "printedName": "Values",
+          "children": [
+            {
+              "kind": "TypeAlias",
+              "name": "Element",
+              "printedName": "Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Value"
+                }
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SD6ValuesV7Elementa",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>"
+            },
+            {
+              "kind": "Var",
+              "name": "startIndex",
+              "printedName": "startIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Dictionary<Key, Value>.Index",
+                      "usr": "s:SD5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD6ValuesV10startIndexSD0C0Vyxq__Gvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD6ValuesV10startIndexSD0C0Vyxq__Gvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "endIndex",
+              "printedName": "endIndex",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "Dictionary<Key, Value>.Index",
+                      "usr": "s:SD5IndexV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD6ValuesV8endIndexSD0C0Vyxq__Gvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD6ValuesV8endIndexSD0C0Vyxq__Gvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "index",
+              "printedName": "index(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD6ValuesV5index5afterSD5IndexVyxq__GAG_tF",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "formIndex",
+              "printedName": "formIndex(after:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD6ValuesV9formIndex5afterySD0C0Vyxq__Gz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Element",
+                  "printedName": "Dictionary<Key, Value>.Values.Element",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SD6ValuesVyq_SD5IndexVyxq__Gcip",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "hasSetter": true
+            },
+            {
+              "kind": "Var",
+              "name": "count",
+              "printedName": "count",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD6ValuesV5countSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD6ValuesV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "isEmpty",
+              "printedName": "isEmpty",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Bool",
+                      "printedName": "Bool",
+                      "usr": "s:Sb"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD6ValuesV7isEmptySbvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD6ValuesV7isEmptySbvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Var",
+              "name": "description",
+              "printedName": "description",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "String",
+                      "printedName": "String",
+                      "usr": "s:SS"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD6ValuesV11descriptionSSvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD6ValuesV11descriptionSSvp",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Var",
+              "name": "debugDescription",
+              "printedName": "debugDescription",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "String",
+                      "printedName": "String",
+                      "usr": "s:SS"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD6ValuesV16debugDescriptionSSvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD6ValuesV16debugDescriptionSSvp",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Function",
+              "name": "swapAt",
+              "printedName": "swapAt(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD6ValuesV6swapAtyySD5IndexVyxq__G_AFtF",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
+            },
+            {
+              "kind": "TypeAlias",
+              "name": "Index",
+              "printedName": "Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SD6ValuesV5Indexa",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "implicit": true
+            },
+            {
+              "kind": "TypeAlias",
+              "name": "SubSequence",
+              "printedName": "SubSequence",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Slice",
+                  "printedName": "Slice<Dictionary<Key, Value>.Values>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Values",
+                      "printedName": "Dictionary<Key, Value>.Values",
+                      "usr": "s:SD6ValuesV"
+                    }
+                  ],
+                  "usr": "s:s5SliceV"
+                }
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SD6ValuesV11SubSequencea",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "implicit": true
+            },
+            {
+              "kind": "TypeAlias",
+              "name": "Indices",
+              "printedName": "Indices",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DefaultIndices",
+                  "printedName": "DefaultIndices<Dictionary<Key, Value>.Values>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Values",
+                      "printedName": "Dictionary<Key, Value>.Values",
+                      "usr": "s:SD6ValuesV"
+                    }
+                  ],
+                  "usr": "s:SI"
+                }
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SD6ValuesV7Indicesa",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "implicit": true
+            },
+            {
+              "kind": "TypeDecl",
+              "name": "Iterator",
+              "printedName": "Iterator",
+              "children": [
+                {
+                  "kind": "Constructor",
+                  "name": "init",
+                  "printedName": "init(_:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Iterator",
+                      "printedName": "Dictionary<Key, Value>.Values.Iterator",
+                      "usr": "s:SD6ValuesV8IteratorV"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Iterator",
+                      "printedName": "Dictionary<Key, Value>.Iterator",
+                      "usr": "s:SD8IteratorV"
+                    }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:SD6ValuesV8IteratorVyADyxq___GSDACVyxq__Gcfc",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "next",
+                  "printedName": "next()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "Value?",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "Value"
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SD6ValuesV8IteratorV4nextq_SgyF",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>",
+                  "declAttributes": [
+                    "Inlinable"
+                  ],
+                  "mutating": true
+                },
+                {
+                  "kind": "TypeAlias",
+                  "name": "Element",
+                  "printedName": "Element",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Value"
+                    }
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:SD6ValuesV8IteratorV7Elementa",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>",
+                  "implicit": true
+                }
+              ],
+              "declKind": "Struct",
+              "usr": "s:SD6ValuesV8IteratorV",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "IteratorProtocol"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "makeIterator",
+              "printedName": "makeIterator()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Iterator",
+                  "printedName": "Dictionary<Key, Value>.Values.Iterator",
+                  "usr": "s:SD6ValuesV8IteratorV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD6ValuesV12makeIteratorAB0C0Vyxq___GyF",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SD6ValuesV",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "MutableCollection",
+            "CustomStringConvertible",
+            "CustomDebugStringConvertible",
+            "Collection",
+            "Sequence"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "[Key : Value]",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Key"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Value"
+                }
+              ],
+              "usr": "s:SD"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Dictionary",
+              "printedName": "[Key : Value]",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Key"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Value"
+                }
+              ],
+              "usr": "s:SD"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SDsSQR_rlE2eeoiySbSDyxq_G_ABtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable, Value : Equatable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "hash",
+          "printedName": "hash(into:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Hasher",
+              "printedName": "Hasher",
+              "usr": "s:s6HasherV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SDsSHR_rlE4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable, Value : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "hashValue",
+          "printedName": "hashValue",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SDsSHR_rlE9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable, Value : Hashable>",
+              "implicit": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SDsSHR_rlE9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Var",
+          "name": "description",
+          "printedName": "description",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD11descriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "Index",
+          "printedName": "Index",
+          "children": [
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD5IndexV2eeoiySbAByxq__G_ADtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Dictionary<Key, Value>.Index",
+                  "usr": "s:SD5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD5IndexV1loiySbAByxq__G_ADtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "hash",
+              "printedName": "hash(into:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Hasher",
+                  "printedName": "Hasher",
+                  "usr": "s:s6HasherV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD5IndexV4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>"
+            },
+            {
+              "kind": "Var",
+              "name": "hashValue",
+              "printedName": "hashValue",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD5IndexV9hashValueSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>",
+                  "implicit": true
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD5IndexV9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SD5IndexV",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "Equatable",
+            "Comparable",
+            "Hashable"
+          ]
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "Iterator",
+          "printedName": "Iterator",
+          "children": [
+            {
+              "kind": "Function",
+              "name": "next",
+              "printedName": "next()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "(key: Key, value: Value)?",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Tuple",
+                      "printedName": "(key: Key, value: Value)",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "Key"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "Value"
+                        }
+                      ]
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SD8IteratorV4nextx3key_q_5valuetSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
+              ],
+              "mutating": true
+            },
+            {
+              "kind": "TypeAlias",
+              "name": "Element",
+              "printedName": "Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(key: Key, value: Value)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Key"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Value"
+                    }
+                  ]
+                }
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SD8IteratorV7Elementa",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>",
+              "implicit": true
+            },
+            {
+              "kind": "Var",
+              "name": "customMirror",
+              "printedName": "customMirror",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Mirror",
+                      "printedName": "Mirror",
+                      "usr": "s:s6MirrorV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SD8IteratorV12customMirrors0C0Vvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Key, Value where Key : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:SD8IteratorV12customMirrors0C0Vvp",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SD8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "CustomReflectable"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s18DictionaryIteratorV12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -29734,11 +31077,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s18DictionaryIteratorV12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value where Key : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -29746,98 +31084,230 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD12customMirrors0B0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD12customMirrors0B0Vvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "popFirst",
+          "printedName": "popFirst()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Dictionary<Key, Value>.Element?",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Element",
+                  "printedName": "Dictionary<Key, Value>.Element",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Tuple",
+                      "printedName": "(key: τ_0_0, value: τ_0_1)",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
+                        },
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_1"
+                        }
+                      ]
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sq"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD8popFirstx3key_q_5valuetSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Var",
+          "name": "capacity",
+          "printedName": "capacity",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SD8capacitySivg",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value where Key : Hashable>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SD8capacitySivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
+        },
+        {
+          "kind": "Function",
+          "name": "reserveCapacity",
+          "printedName": "reserveCapacity(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SD15reserveCapacityyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value where Key : Hashable>",
+          "mutating": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:SD",
+      "moduleName": "Swift",
+      "genericSig": "<Key, Value where Key : Hashable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Encodable",
+        "Decodable",
+        "Sequence",
+        "Collection",
+        "ExpressibleByDictionaryLiteral",
+        "Equatable",
+        "Hashable",
+        "_HasCustomAnyHashableRepresentation",
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible",
+        "CustomReflectable"
       ]
     },
     {
+      "kind": "TypeAlias",
+      "name": "DictionaryIndex",
+      "printedName": "DictionaryIndex",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Index",
+          "printedName": "Dictionary<Key, Value>.Index",
+          "usr": "s:SD5IndexV"
+        }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s15DictionaryIndexa",
+      "moduleName": "Swift",
+      "genericSig": "<Key, Value where Key : Hashable>"
+    },
+    {
+      "kind": "TypeAlias",
+      "name": "DictionaryIterator",
+      "printedName": "DictionaryIterator",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Iterator",
+          "printedName": "Dictionary<Key, Value>.Iterator",
+          "usr": "s:SD8IteratorV"
+        }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s18DictionaryIteratora",
+      "moduleName": "Swift",
+      "genericSig": "<Key, Value where Key : Hashable>"
+    },
+    {
       "kind": "TypeDecl",
       "name": "LazyDropWhileSequence",
       "printedName": "LazyDropWhileSequence",
-      "declKind": "Struct",
-      "usr": "s:s21LazyDropWhileSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Sequence>",
-      "conformingProtocols": [
-        "Sequence",
-        "LazySequenceProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s21LazyDropWhileSequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s21LazyDropWhileSequenceV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>"
         },
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s21LazyDropWhileSequenceV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "conformingProtocols": [
-            "IteratorProtocol"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s21LazyDropWhileSequenceV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Element"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s21LazyDropWhileSequenceV8IteratorV7Elementa",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence>"
             },
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s21LazyDropWhileSequenceV8IteratorV4next7ElementQzSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "LazyDropWhileSequence<Base>.Iterator.Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -29851,49 +31321,59 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s21LazyDropWhileSequenceV8IteratorV4next7ElementQzSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s21LazyDropWhileSequenceV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s21LazyDropWhileSequenceV03SubD0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Base.Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s21LazyDropWhileSequenceV03SubD0a",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>"
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s21LazyDropWhileSequenceV12makeIteratorAB0F0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -29901,81 +31381,77 @@
               "printedName": "LazyDropWhileSequence<Base>.Iterator",
               "usr": "s:s21LazyDropWhileSequenceV8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s21LazyDropWhileSequenceV12makeIteratorAB0F0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Elements",
           "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s21LazyDropWhileSequenceV8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyDropWhileSequence",
               "printedName": "LazyDropWhileSequence<Base>",
-              "usr": "s:s21LazyDropWhileSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "usr": "s:s21LazyDropWhileSequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s21LazyDropWhileSequenceV8Elementsa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s21LazyDropWhileSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<Base where Base : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "LazySequenceProtocol"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "LazyDropWhileCollection",
       "printedName": "LazyDropWhileCollection",
-      "declKind": "Struct",
-      "usr": "s:s23LazyDropWhileCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Collection>",
-      "conformingProtocols": [
-        "Sequence",
-        "Collection",
-        "LazyCollectionProtocol",
-        "LazySequenceProtocol",
-        "BidirectionalCollection"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s23LazyDropWhileCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s23LazyDropWhileCollectionV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s23LazyDropWhileCollectionV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -29983,20 +31459,16 @@
               "printedName": "LazyDropWhileSequence<Base>.Iterator",
               "usr": "s:s21LazyDropWhileSequenceV8IteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s23LazyDropWhileCollectionV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s23LazyDropWhileCollectionV12makeIterators0abC8SequenceV0F0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -30011,67 +31483,56 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s23LazyDropWhileCollectionV12makeIterators0abC8SequenceV0F0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s23LazyDropWhileCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<LazyDropWhileCollection<Base>>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "LazyDropWhileCollection",
                   "printedName": "LazyDropWhileCollection<Base>",
-                  "usr": "s:s23LazyDropWhileCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Base"
                     }
-                  ]
+                  ],
+                  "usr": "s:s23LazyDropWhileCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s23LazyDropWhileCollectionV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "TypeDecl",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "Struct",
-          "usr": "s:s23LazyDropWhileCollectionV5IndexV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "conformingProtocols": [
-            "Equatable",
-            "Comparable",
-            "Hashable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "base",
               "printedName": "base",
-              "declKind": "Var",
-              "usr": "s:s23LazyDropWhileCollectionV5IndexV4baseACQzvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -30082,35 +31543,100 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s23LazyDropWhileCollectionV5IndexV4baseACQzvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Base where Base : Collection>",
-                  "declAttributes": [
-                    "Transparent"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Base.Index"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s23LazyDropWhileCollectionV5IndexV4baseACQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Base where Base : Collection>",
+                  "implicit": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s23LazyDropWhileCollectionV5IndexV4baseACQzvp",
+              "moduleName": "Swift",
+              "fixedbinaryorder": 0,
+              "isLet": true,
+              "hasStorage": true
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "LazyDropWhileCollection<Base>.Index",
+                  "usr": "s:s23LazyDropWhileCollectionV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "LazyDropWhileCollection<Base>.Index",
+                  "usr": "s:s23LazyDropWhileCollectionV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s23LazyDropWhileCollectionV5IndexV2eeoiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "LazyDropWhileCollection<Base>.Index",
+                  "usr": "s:s23LazyDropWhileCollectionV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "LazyDropWhileCollection<Base>.Index",
+                  "usr": "s:s23LazyDropWhileCollectionV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s23LazyDropWhileCollectionV5IndexV1loiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s23LazyDropWhileCollectionV5IndexVsSHACRpzrlE9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -30122,11 +31648,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s23LazyDropWhileCollectionV5IndexVsSHACRpzrlE9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Base where Base : Collection, Base.Index : Hashable>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -30134,22 +31655,24 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s23LazyDropWhileCollectionV5IndexVsSHACRpzrlE9hashValueSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Base where Base : Collection, Base.Index : Hashable>"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s23LazyDropWhileCollectionV5IndexVsSHACRpzrlE9hashValueSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s23LazyDropWhileCollectionV5IndexVsSHACRpzrlE4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection, Base.Index : Hashable>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -30162,21 +31685,33 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s23LazyDropWhileCollectionV5IndexVsSHACRpzrlE4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection, Base.Index : Hashable>",
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s23LazyDropWhileCollectionV5IndexV",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "Equatable",
+            "Comparable",
+            "Hashable"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s23LazyDropWhileCollectionV10startIndexAB0F0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -30188,11 +31723,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s23LazyDropWhileCollectionV10startIndexAB0F0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -30200,21 +31730,24 @@
                   "printedName": "LazyDropWhileCollection<Base>.Index",
                   "usr": "s:s23LazyDropWhileCollectionV5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s23LazyDropWhileCollectionV10startIndexAB0F0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s23LazyDropWhileCollectionV10startIndexAB0F0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s23LazyDropWhileCollectionV8endIndexAB0F0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -30226,11 +31759,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s23LazyDropWhileCollectionV8endIndexAB0F0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -30238,22 +31766,24 @@
                   "printedName": "LazyDropWhileCollection<Base>.Index",
                   "usr": "s:s23LazyDropWhileCollectionV5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s23LazyDropWhileCollectionV8endIndexAB0F0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s23LazyDropWhileCollectionV8endIndexAB0F0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s23LazyDropWhileCollectionV5index5afterAB5IndexVyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -30267,78 +31797,109 @@
               "printedName": "LazyDropWhileCollection<Base>.Index",
               "usr": "s:s23LazyDropWhileCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s23LazyDropWhileCollectionV5index5afterAB5IndexVyx_GAG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Element",
+              "printedName": "LazyDropWhileCollection<Base>.Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "LazyDropWhileCollection<Base>.Index",
+              "usr": "s:s23LazyDropWhileCollectionV5IndexV"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s23LazyDropWhileCollectionVy7ElementQzAB5IndexVyx_Gcip",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s23LazyDropWhileCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DefaultIndices",
               "printedName": "DefaultIndices<LazyDropWhileCollection<Base>>",
-              "usr": "s:SI",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "LazyDropWhileCollection",
                   "printedName": "LazyDropWhileCollection<Base>",
-                  "usr": "s:s23LazyDropWhileCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Base"
                     }
-                  ]
+                  ],
+                  "usr": "s:s23LazyDropWhileCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:SI"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s23LazyDropWhileCollectionV7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Elements",
           "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s23LazyDropWhileCollectionV8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyDropWhileCollection",
               "printedName": "LazyDropWhileCollection<Base>",
-              "usr": "s:s23LazyDropWhileCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "usr": "s:s23LazyDropWhileCollectionV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s23LazyDropWhileCollectionV8Elementsa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s23LazyDropWhileCollectionVsSKRzrlE5index6beforeAB5IndexVyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -30352,24 +31913,35 @@
               "printedName": "LazyDropWhileCollection<Base>.Index",
               "usr": "s:s23LazyDropWhileCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s23LazyDropWhileCollectionVsSKRzrlE5index6beforeAB5IndexVyx_GAG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s23LazyDropWhileCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<Base where Base : Collection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "Collection",
+        "LazyCollectionProtocol",
+        "LazySequenceProtocol",
+        "BidirectionalCollection"
       ]
     },
     {
       "kind": "Function",
       "name": "dump",
       "printedName": "dump(_:to:name:indent:maxDepth:maxItems:)",
-      "declKind": "Func",
-      "usr": "s:s4dump_2to4name6indent8maxDepth0E5Itemsxx_q_zSSSgS3its16TextOutputStreamR_r0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, TargetStream where TargetStream : TextOutputStream>",
-      "declAttributes": [
-        "Semantics",
-        "DiscardableResult",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -30390,8 +31962,6 @@
           "kind": "TypeNominal",
           "name": "Optional",
           "printedName": "String?",
-          "hasDefaultArg": true,
-          "usr": "s:Sq",
           "children": [
             {
               "kind": "TypeNominal",
@@ -30399,7 +31969,9 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "hasDefaultArg": true,
+          "usr": "s:Sq"
         },
         {
           "kind": "TypeNominal",
@@ -30422,22 +31994,20 @@
           "hasDefaultArg": true,
           "usr": "s:Si"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s4dump_2to4name6indent8maxDepth0E5Itemsxx_q_zSSSgS3its16TextOutputStreamR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<T, TargetStream where TargetStream : TextOutputStream>",
+      "declAttributes": [
+        "Semantics",
+        "DiscardableResult"
       ]
     },
     {
       "kind": "Function",
       "name": "dump",
       "printedName": "dump(_:name:indent:maxDepth:maxItems:)",
-      "declKind": "Func",
-      "usr": "s:s4dump_4name6indent8maxDepth0D5Itemsxx_SSSgS3itlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "declAttributes": [
-        "Semantics",
-        "DiscardableResult",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -30453,8 +32023,6 @@
           "kind": "TypeNominal",
           "name": "Optional",
           "printedName": "String?",
-          "hasDefaultArg": true,
-          "usr": "s:Sq",
           "children": [
             {
               "kind": "TypeNominal",
@@ -30462,7 +32030,9 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "hasDefaultArg": true,
+          "usr": "s:Sq"
         },
         {
           "kind": "TypeNominal",
@@ -30485,86 +32055,57 @@
           "hasDefaultArg": true,
           "usr": "s:Si"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s4dump_4name6indent8maxDepth0D5Itemsxx_SSSgS3itlF",
+      "moduleName": "Swift",
+      "genericSig": "<T>",
+      "declAttributes": [
+        "Semantics",
+        "DiscardableResult"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "EmptyCollection",
       "printedName": "EmptyCollection",
-      "declKind": "Struct",
-      "usr": "s:s15EmptyCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "Sequence",
-        "RandomAccessCollection",
-        "MutableCollection",
-        "BidirectionalCollection",
-        "Collection",
-        "Equatable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s15EmptyCollectionVAByxGycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "EmptyCollection",
               "printedName": "EmptyCollection<Element>",
-              "usr": "s:s15EmptyCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s15EmptyCollectionV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s15EmptyCollectionVAByxGycfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s15EmptyCollectionV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "conformingProtocols": [
-            "IteratorProtocol",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init()",
-              "declKind": "Constructor",
-              "usr": "s:s15EmptyCollectionV8IteratorVADyx_Gycfc",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -30572,63 +32113,64 @@
                   "printedName": "EmptyCollection<Element>.Iterator",
                   "usr": "s:s15EmptyCollectionV8IteratorV"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s15EmptyCollectionV8IteratorVADyx_Gycfc",
+              "moduleName": "Swift",
+              "genericSig": "<Element>",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s15EmptyCollectionV8IteratorV4nextxSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s15EmptyCollectionV8IteratorV4nextxSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<Element>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s15EmptyCollectionV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s15EmptyCollectionV8IteratorV7Elementa",
+              "moduleName": "Swift",
+              "genericSig": "<Element>",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s15EmptyCollectionV8IteratorVACa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -30636,47 +32178,55 @@
                   "printedName": "EmptyCollection<Element>.Iterator",
                   "usr": "s:s15EmptyCollectionV8IteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s15EmptyCollectionV8IteratorVACa",
+              "moduleName": "Swift",
+              "genericSig": "<Element>",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s15EmptyCollectionV8IteratorV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnySequence",
                   "printedName": "AnySequence<Element>",
-                  "usr": "s:s11AnySequenceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s11AnySequenceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s15EmptyCollectionV8IteratorV11SubSequencea",
+              "moduleName": "Swift",
+              "genericSig": "<Element>",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s15EmptyCollectionV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "Sequence"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s15EmptyCollectionV12makeIteratorAB0D0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -30684,17 +32234,19 @@
               "printedName": "EmptyCollection<Element>.Iterator",
               "usr": "s:s15EmptyCollectionV8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15EmptyCollectionV12makeIteratorAB0D0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s15EmptyCollectionV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -30702,23 +32254,21 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15EmptyCollectionV5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s15EmptyCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Int>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -30726,46 +32276,43 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15EmptyCollectionV7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s15EmptyCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "EmptyCollection",
               "printedName": "EmptyCollection<Element>",
-              "usr": "s:s15EmptyCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s15EmptyCollectionV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15EmptyCollectionV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s15EmptyCollectionV10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -30784,11 +32331,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15EmptyCollectionV10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -30803,21 +32345,24 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15EmptyCollectionV10startIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15EmptyCollectionV10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s15EmptyCollectionV8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -30836,11 +32381,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15EmptyCollectionV8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -30855,22 +32395,24 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15EmptyCollectionV8endIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15EmptyCollectionV8endIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s15EmptyCollectionV5index5afterS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -30898,33 +32440,64 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15EmptyCollectionV5index5afterS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "EmptyCollection<Element>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "EmptyCollection<Element>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ]
+            }
+          ],
           "declKind": "Func",
           "usr": "s:s15EmptyCollectionV5index6beforeS2i_tF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Element>",
           "declAttributes": [
             "Inlinable"
-          ],
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "EmptyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Element"
             },
             {
               "kind": "TypeNameAlias",
@@ -30939,111 +32512,45 @@
                 }
               ]
             }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "count",
-          "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s15EmptyCollectionV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15EmptyCollectionV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s15EmptyCollectionV5index_8offsetByS2i_SitF",
-          "location": "",
+          "declKind": "Subscript",
+          "usr": "s:s15EmptyCollectionVyxSicip",
           "moduleName": "Swift",
           "genericSig": "<Element>",
           "declAttributes": [
             "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "EmptyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "EmptyCollection<Element>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
+          "hasSetter": true
         },
         {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s15EmptyCollectionV5index_8offsetBy07limitedE0SiSgSi_S2itF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
+              "kind": "TypeNameAlias",
+              "name": "SubSequence",
+              "printedName": "EmptyCollection<Element>.SubSequence",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "EmptyCollection",
+                  "printedName": "EmptyCollection<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:s15EmptyCollectionV"
+                }
+              ]
+            },
+            {
               "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "EmptyCollection<Element>.Index?",
-              "usr": "s:Sq",
+              "name": "Range",
+              "printedName": "Range<EmptyCollection<Element>.Index>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -31058,6 +32565,71 @@
                     }
                   ]
                 }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s15EmptyCollectionVyAByxGSnySiGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Var",
+          "name": "count",
+          "printedName": "count",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15EmptyCollectionV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15EmptyCollectionV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "EmptyCollection<Element>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
               ]
             },
             {
@@ -31078,6 +32650,60 @@
               "name": "Int",
               "printedName": "Int",
               "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15EmptyCollectionV5index_8offsetByS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(_:offsetBy:limitedBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "EmptyCollection<Element>.Index?",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "EmptyCollection<Element>.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "EmptyCollection<Element>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
             },
             {
               "kind": "TypeNameAlias",
@@ -31092,20 +32718,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15EmptyCollectionV5index_8offsetBy07limitedE0SiSgSi_S2itF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s15EmptyCollectionV8distance4from2toS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -31139,87 +32764,306 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15EmptyCollectionV8distance4from2toS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s15EmptyCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15EmptyCollectionV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "EmptyCollection",
+              "printedName": "EmptyCollection<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:s15EmptyCollectionV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "EmptyCollection",
+              "printedName": "EmptyCollection<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:s15EmptyCollectionV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15EmptyCollectionV2eeoiySbAByxG_ADtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s15EmptyCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<Element>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "RandomAccessCollection",
+        "MutableCollection",
+        "BidirectionalCollection",
+        "Collection",
+        "Equatable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Equatable",
       "printedName": "Equatable",
+      "children": [
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SQ2eeoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Equatable>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "!=",
+          "printedName": "!=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SQsE2neoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Equatable>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        }
+      ],
       "declKind": "Protocol",
       "usr": "s:SQ",
-      "location": "",
       "moduleName": "Swift"
     },
     {
+      "kind": "Function",
+      "name": "===",
+      "printedName": "===(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "AnyObject?",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "AnyObject",
+              "printedName": "AnyObject",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ProtocolComposition",
+                  "printedName": "AnyObject"
+                }
+              ]
+            }
+          ],
+          "usr": "s:Sq"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "AnyObject?",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "AnyObject",
+              "printedName": "AnyObject",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ProtocolComposition",
+                  "printedName": "AnyObject"
+                }
+              ]
+            }
+          ],
+          "usr": "s:Sq"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s3eeeoiySbyXlSg_ABtF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!==",
+      "printedName": "!==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "AnyObject?",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "AnyObject",
+              "printedName": "AnyObject",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ProtocolComposition",
+                  "printedName": "AnyObject"
+                }
+              ]
+            }
+          ],
+          "usr": "s:Sq"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "AnyObject?",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "AnyObject",
+              "printedName": "AnyObject",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "ProtocolComposition",
+                  "printedName": "AnyObject"
+                }
+              ]
+            }
+          ],
+          "usr": "s:Sq"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s3neeoiySbyXlSg_ABtF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
       "kind": "TypeDecl",
       "name": "Error",
       "printedName": "Error",
       "declKind": "Protocol",
       "usr": "s:s5ErrorP",
-      "location": "",
       "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "LazyFilterSequence",
       "printedName": "LazyFilterSequence",
-      "declKind": "Struct",
-      "usr": "s:s18LazyFilterSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Sequence>",
-      "conformingProtocols": [
-        "LazySequenceProtocol",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s18LazyFilterSequenceV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "conformingProtocols": [
-            "IteratorProtocol",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "base",
               "printedName": "base",
-              "declKind": "Var",
-              "usr": "s:s18LazyFilterSequenceV8IteratorV4baseACQzvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -31230,57 +33074,48 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s18LazyFilterSequenceV8IteratorV4baseACQzvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Base where Base : Sequence>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Base.Iterator"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s18LazyFilterSequenceV8IteratorV4baseACQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Base where Base : Sequence>"
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s18LazyFilterSequenceV8IteratorV4baseACQzvp",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s18LazyFilterSequenceV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Element"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s18LazyFilterSequenceV8IteratorV7Elementa",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence>"
             },
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s18LazyFilterSequenceV8IteratorV4next7ElementQzSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "LazyFilterSequence<Base>.Iterator.Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -31294,19 +33129,23 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s18LazyFilterSequenceV8IteratorV4next7ElementQzSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s18LazyFilterSequenceV8IteratorVACa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -31314,64 +33153,71 @@
                   "printedName": "LazyFilterSequence<Base>.Iterator",
                   "usr": "s:s18LazyFilterSequenceV8IteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s18LazyFilterSequenceV8IteratorVACa",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence>",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s18LazyFilterSequenceV8IteratorV03SubC0a",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnySequence",
                   "printedName": "AnySequence<Base.Element>",
-                  "usr": "s:s11AnySequenceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Base.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s11AnySequenceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s18LazyFilterSequenceV8IteratorV03SubC0a",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence>",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s18LazyFilterSequenceV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "Sequence"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s18LazyFilterSequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s18LazyFilterSequenceV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>"
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s18LazyFilterSequenceV12makeIteratorAB0E0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -31379,106 +33225,103 @@
               "printedName": "LazyFilterSequence<Base>.Iterator",
               "usr": "s:s18LazyFilterSequenceV8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s18LazyFilterSequenceV12makeIteratorAB0E0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Elements",
           "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s18LazyFilterSequenceV8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyFilterSequence",
               "printedName": "LazyFilterSequence<Base>",
-              "usr": "s:s18LazyFilterSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "usr": "s:s18LazyFilterSequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s18LazyFilterSequenceV8Elementsa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s18LazyFilterSequenceV03SubC0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Base.Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s18LazyFilterSequenceV03SubC0a",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s18LazyFilterSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<Base where Base : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "LazySequenceProtocol",
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "LazyFilterCollection",
       "printedName": "LazyFilterCollection",
-      "declKind": "Struct",
-      "usr": "s:s20LazyFilterCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Collection>",
-      "conformingProtocols": [
-        "LazySequenceProtocol",
-        "Sequence",
-        "LazyCollectionProtocol",
-        "Collection",
-        "BidirectionalCollection"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s20LazyFilterCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s20LazyFilterCollectionV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s20LazyFilterCollectionV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -31486,44 +33329,40 @@
               "printedName": "LazyFilterSequence<Base>.Iterator",
               "usr": "s:s18LazyFilterSequenceV8IteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s20LazyFilterCollectionV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s20LazyFilterCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyFilterCollection",
               "printedName": "LazyFilterCollection<Base.SubSequence>",
-              "usr": "s:s20LazyFilterCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.SubSequence"
                 }
-              ]
+              ],
+              "usr": "s:s20LazyFilterCollectionV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s20LazyFilterCollectionV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s20LazyFilterCollectionV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -31535,11 +33374,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20LazyFilterCollectionV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -31547,22 +33381,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20LazyFilterCollectionV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20LazyFilterCollectionV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionV12makeIterators0aB8SequenceV0E0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -31577,61 +33413,60 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionV12makeIterators0aB8SequenceV0E0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Elements",
           "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s20LazyFilterCollectionV8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyFilterCollection",
               "printedName": "LazyFilterCollection<Base>",
-              "usr": "s:s20LazyFilterCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "usr": "s:s20LazyFilterCollectionV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s20LazyFilterCollectionV8Elementsa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s20LazyFilterCollectionV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Index"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s20LazyFilterCollectionV5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s20LazyFilterCollectionV10startIndex0E0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -31642,32 +33477,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20LazyFilterCollectionV10startIndex0E0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Index"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20LazyFilterCollectionV10startIndex0E0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20LazyFilterCollectionV10startIndex0E0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s20LazyFilterCollectionV8endIndex0E0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -31678,33 +33511,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20LazyFilterCollectionV8endIndex0E0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Index"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20LazyFilterCollectionV8endIndex0E0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20LazyFilterCollectionV8endIndex0E0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionV5index5after5IndexQzAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -31730,20 +33560,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionV5index5after5IndexQzAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionV9formIndex5aftery0E0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -31762,20 +33591,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionV9formIndex5aftery0E0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionV8distance4from2toSi5IndexQz_AGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -31807,20 +33635,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionV8distance4from2toSi5IndexQz_AGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionV5index_8offsetBy5IndexQzAF_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -31852,20 +33679,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionV5index_8offsetBy5IndexQzAF_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionV9formIndex_8offsetByy0E0Qzz_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -31890,26 +33716,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionV9formIndex_8offsetByy0E0Qzz_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionV5index_8offsetBy07limitedF05IndexQzSgAG_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "LazyFilterCollection<Base>.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -31923,7 +33747,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -31955,20 +33780,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionV5index_8offsetBy07limitedF05IndexQzSgAG_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionV9formIndex_8offsetBy07limitedG0Sb0E0Qzz_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32006,53 +33830,144 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionV9formIndex_8offsetBy07limitedG0Sb0E0Qzz_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Element",
+              "printedName": "LazyFilterCollection<Base>.Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "LazyFilterCollection<Base>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ]
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s20LazyFilterCollectionVy7ElementQz5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "SubSequence",
+              "printedName": "LazyFilterCollection<Base>.SubSequence",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "LazyFilterCollection",
+                  "printedName": "LazyFilterCollection<τ_0_0.SubSequence>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.SubSequence"
+                    }
+                  ],
+                  "usr": "s:s20LazyFilterCollectionV"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<LazyFilterCollection<Base>.Index>",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "LazyFilterCollection<Base>.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Index"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s20LazyFilterCollectionVyABy11SubSequenceQzGSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s20LazyFilterCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DefaultIndices",
               "printedName": "DefaultIndices<LazyFilterCollection<Base>>",
-              "usr": "s:SI",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "LazyFilterCollection",
                   "printedName": "LazyFilterCollection<Base>",
-                  "usr": "s:s20LazyFilterCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Base"
                     }
-                  ]
+                  ],
+                  "usr": "s:s20LazyFilterCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:SI"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s20LazyFilterCollectionV7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionVsSKRzrlE5index6before5IndexQzAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -32078,20 +33993,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionVsSKRzrlE5index6before5IndexQzAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:s20LazyFilterCollectionVsSKRzrlE9formIndex6beforey0E0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32110,79 +34024,66 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazyFilterCollectionVsSKRzrlE9formIndex6beforey0E0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s20LazyFilterCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<Base where Base : Collection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "LazySequenceProtocol",
+        "Sequence",
+        "LazyCollectionProtocol",
+        "Collection",
+        "BidirectionalCollection"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "FlattenSequence",
       "printedName": "FlattenSequence",
-      "declKind": "Struct",
-      "usr": "s:s15FlattenSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-      "conformingProtocols": [
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s15FlattenSequenceV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-          "conformingProtocols": [
-            "IteratorProtocol",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s15FlattenSequenceV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Element.Element"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s15FlattenSequenceV8IteratorV7Elementa",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>"
             },
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s15FlattenSequenceV8IteratorV4next7Element_AFQZSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "FlattenSequence<Base>.Iterator.Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -32196,19 +34097,23 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s15FlattenSequenceV8IteratorV4next7Element_AFQZSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s15FlattenSequenceV8IteratorVACa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -32216,47 +34121,55 @@
                   "printedName": "FlattenSequence<Base>.Iterator",
                   "usr": "s:s15FlattenSequenceV8IteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s15FlattenSequenceV8IteratorVACa",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s15FlattenSequenceV8IteratorV03SubB0a",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnySequence",
                   "printedName": "AnySequence<Base.Element.Element>",
-                  "usr": "s:s11AnySequenceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Base.Element.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s11AnySequenceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s15FlattenSequenceV8IteratorV03SubB0a",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s15FlattenSequenceV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "Sequence"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s15FlattenSequenceV12makeIteratorAB0D0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32264,133 +34177,181 @@
               "printedName": "FlattenSequence<Base>.Iterator",
               "usr": "s:s15FlattenSequenceV8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15FlattenSequenceV12makeIteratorAB0D0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s15FlattenSequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Element.Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15FlattenSequenceV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s15FlattenSequenceV03SubB0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Base.Element.Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Element.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15FlattenSequenceV03SubB0a",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s15FlattenSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "FlattenCollection",
       "printedName": "FlattenCollection",
-      "declKind": "Struct",
-      "usr": "s:s17FlattenCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-      "conformingProtocols": [
-        "Sequence",
-        "Collection",
-        "BidirectionalCollection"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FlattenCollectionVyAByxGxcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "FlattenCollection",
               "printedName": "FlattenCollection<Base>",
-              "usr": "s:s17FlattenCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "usr": "s:s17FlattenCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Base"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FlattenCollectionVyAByxGxcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "Struct",
-          "usr": "s:s17FlattenCollectionV5IndexV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "conformingProtocols": [
-            "Equatable",
-            "Comparable",
-            "Hashable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "FlattenCollection<Base>.Index",
+                  "usr": "s:s17FlattenCollectionV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "FlattenCollection<Base>.Index",
+                  "usr": "s:s17FlattenCollectionV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s17FlattenCollectionV5IndexV2eeoiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "FlattenCollection<Base>.Index",
+                  "usr": "s:s17FlattenCollectionV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "FlattenCollection<Base>.Index",
+                  "usr": "s:s17FlattenCollectionV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s17FlattenCollectionV5IndexV1loiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s17FlattenCollectionV5IndexVsSHACRpzSH7Element_ACRPzrlE4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection, Base.Element : Collection, Base.Index : Hashable, Base.Element.Index : Hashable>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -32403,16 +34364,19 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s17FlattenCollectionV5IndexVsSHACRpzSH7Element_ACRPzrlE4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection, Base.Element : Collection, Base.Index : Hashable, Base.Element.Index : Hashable>",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s17FlattenCollectionV5IndexVsSHACRpzSH7Element_ACRPzrlE9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -32424,11 +34388,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s17FlattenCollectionV5IndexVsSHACRpzSH7Element_ACRPzrlE9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Base where Base : Collection, Base.Element : Collection, Base.Index : Hashable, Base.Element.Index : Hashable>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -32436,21 +34395,37 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s17FlattenCollectionV5IndexVsSHACRpzSH7Element_ACRPzrlE9hashValueSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Base where Base : Collection, Base.Element : Collection, Base.Index : Hashable, Base.Element.Index : Hashable>",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s17FlattenCollectionV5IndexVsSHACRpzSH7Element_ACRPzrlE9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s17FlattenCollectionV5IndexV",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "Equatable",
+            "Comparable",
+            "Hashable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s17FlattenCollectionV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -32458,53 +34433,48 @@
               "printedName": "FlattenSequence<Base>.Iterator",
               "usr": "s:s15FlattenSequenceV8IteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s17FlattenCollectionV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection, Base.Element : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s17FlattenCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<FlattenCollection<Base>>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "FlattenCollection",
                   "printedName": "FlattenCollection<Base>",
-                  "usr": "s:s17FlattenCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Base"
                     }
-                  ]
+                  ],
+                  "usr": "s:s17FlattenCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s17FlattenCollectionV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection, Base.Element : Collection>"
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV12makeIterators0A8SequenceV0D0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -32519,16 +34489,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV12makeIterators0A8SequenceV0D0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s17FlattenCollectionV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -32540,11 +34513,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FlattenCollectionV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -32552,24 +34520,21 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FlattenCollectionV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection, Base.Element : Collection>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FlattenCollectionV19underestimatedCountSivp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "forEach",
           "printedName": "forEach(_:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV7forEachyyy7Element_ADQZKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32580,9 +34545,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Base.Element.Element) throws -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -32608,21 +34570,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV7forEachyyy7Element_ADQZKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s17FlattenCollectionV10startIndexAB0D0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32634,11 +34601,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FlattenCollectionV10startIndexAB0D0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -32646,21 +34608,24 @@
                   "printedName": "FlattenCollection<Base>.Index",
                   "usr": "s:s17FlattenCollectionV5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FlattenCollectionV10startIndexAB0D0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection, Base.Element : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FlattenCollectionV10startIndexAB0D0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s17FlattenCollectionV8endIndexAB0D0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32672,11 +34637,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FlattenCollectionV8endIndexAB0D0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -32684,22 +34644,24 @@
                   "printedName": "FlattenCollection<Base>.Index",
                   "usr": "s:s17FlattenCollectionV5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FlattenCollectionV8endIndexAB0D0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection, Base.Element : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FlattenCollectionV8endIndexAB0D0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV5index5afterAB5IndexVyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32713,20 +34675,19 @@
               "printedName": "FlattenCollection<Base>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV5index5afterAB5IndexVyx_GAG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV9formIndex5afteryAB0D0Vyx_Gz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32739,20 +34700,19 @@
               "printedName": "FlattenCollection<Base>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV9formIndex5afteryAB0D0Vyx_Gz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV8distance4from2toSiAB5IndexVyx_G_AHtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32772,20 +34732,19 @@
               "printedName": "FlattenCollection<Base>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV8distance4from2toSiAB5IndexVyx_G_AHtF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV5index_8offsetByAB5IndexVyx_GAG_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32805,20 +34764,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV5index_8offsetByAB5IndexVyx_GAG_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV9formIndex_8offsetByyAB0D0Vyx_Gz_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32837,26 +34795,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV9formIndex_8offsetByyAB0D0Vyx_Gz_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV5index_8offsetBy07limitedE0AB5IndexVyx_GSgAH_SiAHtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "FlattenCollection<Base>.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -32864,7 +34820,8 @@
                   "printedName": "FlattenCollection<Base>.Index",
                   "usr": "s:s17FlattenCollectionV5IndexV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -32884,20 +34841,19 @@
               "printedName": "FlattenCollection<Base>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV5index_8offsetBy07limitedE0AB5IndexVyx_GSgAH_SiAHtF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionV9formIndex_8offsetBy07limitedF0SbAB0D0Vyx_Gz_SiAHtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -32923,70 +34879,150 @@
               "printedName": "FlattenCollection<Base>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionV9formIndex_8offsetBy07limitedF0SbAB0D0Vyx_Gz_SiAHtF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Base.Element.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "FlattenCollection<Base>.Index",
+              "usr": "s:s17FlattenCollectionV5IndexV"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s17FlattenCollectionVy7Element_ACQZAB5IndexVyx_Gcip",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "SubSequence",
+              "printedName": "FlattenCollection<Base>.SubSequence",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Slice",
+                  "printedName": "Slice<FlattenCollection<τ_0_0>>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "FlattenCollection",
+                      "printedName": "FlattenCollection<τ_0_0>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
+                        }
+                      ],
+                      "usr": "s:s17FlattenCollectionV"
+                    }
+                  ],
+                  "usr": "s:s5SliceV"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<FlattenCollection<Base>.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "FlattenCollection<Base>.Index",
+                  "usr": "s:s17FlattenCollectionV5IndexV"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s17FlattenCollectionVys5SliceVyAByxGGSnyAB5IndexVyx_GGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s17FlattenCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Element.Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s17FlattenCollectionV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s17FlattenCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DefaultIndices",
               "printedName": "DefaultIndices<FlattenCollection<Base>>",
-              "usr": "s:SI",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "FlattenCollection",
                   "printedName": "FlattenCollection<Base>",
-                  "usr": "s:s17FlattenCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Base"
                     }
-                  ]
+                  ],
+                  "usr": "s:s17FlattenCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:SI"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s17FlattenCollectionV7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionVsSKRzSK7ElementRpzrlE5index6beforeAB5IndexVyx_GAI_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection, Base.Element : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -33000,20 +35036,19 @@
               "printedName": "FlattenCollection<Base>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionVsSKRzSK7ElementRpzrlE5index6beforeAB5IndexVyx_GAI_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection, Base.Element : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:s17FlattenCollectionVsSKRzSK7ElementRpzrlE9formIndex6beforeyAB0E0Vyx_Gz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection, Base.Element : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -33026,17 +35061,2259 @@
               "printedName": "FlattenCollection<Base>.Index",
               "usr": "s:s17FlattenCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FlattenCollectionVsSKRzSK7ElementRpzrlE9formIndex6beforeyAB0E0Vyx_Gz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection, Base.Element : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s17FlattenCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<Base where Base : Collection, Base.Element : Collection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "Collection",
+        "BidirectionalCollection"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "FloatingPoint",
       "printedName": "FloatingPoint",
+      "children": [
+        {
+          "kind": "AssociatedType",
+          "name": "Exponent",
+          "printedName": "Exponent",
+          "declKind": "AssociatedType",
+          "usr": "s:SF8ExponentQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(sign:exponent:significand:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointSign",
+              "printedName": "FloatingPointSign",
+              "usr": "s:s17FloatingPointSignO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Exponent"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SF4sign8exponent11significandxs17FloatingPointSignO_8ExponentQzxtcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(signOf:magnitudeOf:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SF6signOf09magnitudeB0xx_xtcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SFyxSicfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Source"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SFyxqd__cSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Source where Self : FloatingPoint, Source : BinaryInteger>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Self?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Source"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SF7exactlyxSgqd___tcSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Source where Self : FloatingPoint, Source : BinaryInteger>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "radix",
+          "printedName": "radix",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF5radixSivgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF5radixSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "nan",
+          "printedName": "nan",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF3nanxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF3nanxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "signalingNaN",
+          "printedName": "signalingNaN",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF12signalingNaNxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF12signalingNaNxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "infinity",
+          "printedName": "infinity",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF8infinityxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF8infinityxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "greatestFiniteMagnitude",
+          "printedName": "greatestFiniteMagnitude",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF23greatestFiniteMagnitudexvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF23greatestFiniteMagnitudexvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "pi",
+          "printedName": "pi",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF2pixvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF2pixvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "ulp",
+          "printedName": "ulp",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF3ulpxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF3ulpxvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "ulpOfOne",
+          "printedName": "ulpOfOne",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF8ulpOfOnexvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF8ulpOfOnexvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "leastNormalMagnitude",
+          "printedName": "leastNormalMagnitude",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF20leastNormalMagnitudexvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF20leastNormalMagnitudexvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "leastNonzeroMagnitude",
+          "printedName": "leastNonzeroMagnitude",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF21leastNonzeroMagnitudexvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF21leastNonzeroMagnitudexvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "sign",
+          "printedName": "sign",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointSign",
+              "printedName": "FloatingPointSign",
+              "usr": "s:s17FloatingPointSignO"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "FloatingPointSign",
+                  "printedName": "FloatingPointSign",
+                  "usr": "s:s17FloatingPointSignO"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF4signs17FloatingPointSignOvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF4signs17FloatingPointSignOvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "exponent",
+          "printedName": "exponent",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Exponent"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "Self.Exponent"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF8exponent8ExponentQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF8exponent8ExponentQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "significand",
+          "printedName": "significand",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF11significandxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF11significandxvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF1poiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF2peoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF1sopyxxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Prefix",
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "negate",
+          "printedName": "negate()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF6negateyyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF1soiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF2seoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF1moiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF2meoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF1doiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF2deoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "remainder",
+          "printedName": "remainder(dividingBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF9remainder10dividingByxx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "formRemainder",
+          "printedName": "formRemainder(dividingBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF13formRemainder10dividingByyx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "truncatingRemainder",
+          "printedName": "truncatingRemainder(dividingBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF19truncatingRemainder10dividingByxx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "formTruncatingRemainder",
+          "printedName": "formTruncatingRemainder(dividingBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF23formTruncatingRemainder10dividingByyx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "squareRoot",
+          "printedName": "squareRoot()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF10squareRootxyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "formSquareRoot",
+          "printedName": "formSquareRoot()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF14formSquareRootyyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "addingProduct",
+          "printedName": "addingProduct(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF13addingProductyxx_xtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "addProduct",
+          "printedName": "addProduct(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF10addProductyyx_xtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "minimum",
+          "printedName": "minimum(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF7minimumyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "maximum",
+          "printedName": "maximum(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF7maximumyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "minimumMagnitude",
+          "printedName": "minimumMagnitude(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF16minimumMagnitudeyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "maximumMagnitude",
+          "printedName": "maximumMagnitude(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF16maximumMagnitudeyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "rounded",
+          "printedName": "rounded(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointRoundingRule",
+              "printedName": "FloatingPointRoundingRule",
+              "usr": "s:s25FloatingPointRoundingRuleO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF7roundedyxs25FloatingPointRoundingRuleOF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "round",
+          "printedName": "round(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointRoundingRule",
+              "printedName": "FloatingPointRoundingRule",
+              "usr": "s:s25FloatingPointRoundingRuleO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF5roundyys25FloatingPointRoundingRuleOF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true,
+          "mutating": true
+        },
+        {
+          "kind": "Var",
+          "name": "nextUp",
+          "printedName": "nextUp",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF6nextUpxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF6nextUpxvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "nextDown",
+          "printedName": "nextDown",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF8nextDownxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF8nextDownxvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "isEqual",
+          "printedName": "isEqual(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF7isEqual2toSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "isLess",
+          "printedName": "isLess(than:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF6isLess4thanSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "isLessThanOrEqualTo",
+          "printedName": "isLessThanOrEqualTo(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF19isLessThanOrEqualToySbxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "isTotallyOrdered",
+          "printedName": "isTotallyOrdered(belowOrEqualTo:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SF16isTotallyOrdered14belowOrEqualToSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "isNormal",
+          "printedName": "isNormal",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF8isNormalSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF8isNormalSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "isFinite",
+          "printedName": "isFinite",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF8isFiniteSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF8isFiniteSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "isZero",
+          "printedName": "isZero",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF6isZeroSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF6isZeroSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "isSubnormal",
+          "printedName": "isSubnormal",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF11isSubnormalSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF11isSubnormalSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "isInfinite",
+          "printedName": "isInfinite",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF10isInfiniteSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF10isInfiniteSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "isNaN",
+          "printedName": "isNaN",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF5isNaNSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF5isNaNSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "isSignalingNaN",
+          "printedName": "isSignalingNaN",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF14isSignalingNaNSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF14isSignalingNaNSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "floatingPointClass",
+          "printedName": "floatingPointClass",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointClassification",
+              "printedName": "FloatingPointClassification",
+              "usr": "s:s27FloatingPointClassificationO"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "FloatingPointClassification",
+                  "printedName": "FloatingPointClassification",
+                  "usr": "s:s27FloatingPointClassificationO"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF18floatingPointClasss08FloatingB14ClassificationOvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF18floatingPointClasss08FloatingB14ClassificationOvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Var",
+          "name": "isCanonical",
+          "printedName": "isCanonical",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SF11isCanonicalSbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SF11isCanonicalSbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE2eeoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE1loiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE2leoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE1goiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE2geoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "ulpOfOne",
+          "printedName": "ulpOfOne",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SFsE8ulpOfOnexvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SFsE8ulpOfOnexvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "rounded",
+          "printedName": "rounded(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointRoundingRule",
+              "printedName": "FloatingPointRoundingRule",
+              "usr": "s:s25FloatingPointRoundingRuleO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE7roundedyxs25FloatingPointRoundingRuleOF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "rounded",
+          "printedName": "rounded()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE7roundedxyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "round",
+          "printedName": "round()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE5roundyyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Var",
+          "name": "nextDown",
+          "printedName": "nextDown",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SFsE8nextDownxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SFsE8nextDownxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "truncatingRemainder",
+          "printedName": "truncatingRemainder(dividingBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE19truncatingRemainder10dividingByxx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "remainder",
+          "printedName": "remainder(dividingBy:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE9remainder10dividingByxx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "squareRoot",
+          "printedName": "squareRoot()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE10squareRootxyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "addingProduct",
+          "printedName": "addingProduct(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE13addingProductyxx_xtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "minimum",
+          "printedName": "minimum(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE7minimumyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "maximum",
+          "printedName": "maximum(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE7maximumyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "minimumMagnitude",
+          "printedName": "minimumMagnitude(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE16minimumMagnitudeyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "maximumMagnitude",
+          "printedName": "maximumMagnitude(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SFsE16maximumMagnitudeyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FloatingPoint>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "floatingPointClass",
+          "printedName": "floatingPointClass",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointClassification",
+              "printedName": "FloatingPointClassification",
+              "usr": "s:s27FloatingPointClassificationO"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "FloatingPointClassification",
+                  "printedName": "FloatingPointClassification",
+                  "usr": "s:s27FloatingPointClassificationO"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SFsE18floatingPointClasss08FloatingB14ClassificationOvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FloatingPoint>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SFsE18floatingPointClasss08FloatingB14ClassificationOvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        }
+      ],
       "declKind": "Protocol",
       "usr": "s:SF",
-      "location": "",
       "moduleName": "Swift",
       "genericSig": "<Self : Hashable, Self : SignedNumeric, Self : Strideable, Self == Self.Magnitude, Self.Exponent : SignedInteger>",
       "conformingProtocols": [
@@ -33047,2313 +37324,17 @@
         "Comparable",
         "Equatable",
         "ExpressibleByIntegerLiteral"
-      ],
-      "children": [
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(sign:exponent:significand:)",
-          "declKind": "Constructor",
-          "usr": "s:SF4sign8exponent11significandxs17FloatingPointSignO_8ExponentQzxtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "FloatingPointSign",
-              "printedName": "FloatingPointSign",
-              "usr": "s:s17FloatingPointSignO"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Exponent"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(signOf:magnitudeOf:)",
-          "declKind": "Constructor",
-          "usr": "s:SF6signOf09magnitudeB0xx_xtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxs5UInt8Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxs4Int8Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxs6UInt16Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxs5Int16Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxs6UInt32Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxs5Int32Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxs6UInt64Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxs5Int64Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxSucfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxSicfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SFyxqd__cSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Source where Self : FloatingPoint, Source : BinaryInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Source"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:SF7exactlyxSgqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Source where Self : FloatingPoint, Source : BinaryInteger>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Source"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "radix",
-          "printedName": "radix",
-          "declKind": "Var",
-          "usr": "s:SF5radixSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF5radixSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "nan",
-          "printedName": "nan",
-          "declKind": "Var",
-          "usr": "s:SF3nanxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF3nanxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "signalingNaN",
-          "printedName": "signalingNaN",
-          "declKind": "Var",
-          "usr": "s:SF12signalingNaNxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF12signalingNaNxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "infinity",
-          "printedName": "infinity",
-          "declKind": "Var",
-          "usr": "s:SF8infinityxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF8infinityxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "greatestFiniteMagnitude",
-          "printedName": "greatestFiniteMagnitude",
-          "declKind": "Var",
-          "usr": "s:SF23greatestFiniteMagnitudexvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF23greatestFiniteMagnitudexvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "pi",
-          "printedName": "pi",
-          "declKind": "Var",
-          "usr": "s:SF2pixvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF2pixvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "ulp",
-          "printedName": "ulp",
-          "declKind": "Var",
-          "usr": "s:SF3ulpxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF3ulpxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "ulpOfOne",
-          "printedName": "ulpOfOne",
-          "declKind": "Var",
-          "usr": "s:SF8ulpOfOnexvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF8ulpOfOnexvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "leastNormalMagnitude",
-          "printedName": "leastNormalMagnitude",
-          "declKind": "Var",
-          "usr": "s:SF20leastNormalMagnitudexvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF20leastNormalMagnitudexvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "leastNonzeroMagnitude",
-          "printedName": "leastNonzeroMagnitude",
-          "declKind": "Var",
-          "usr": "s:SF21leastNonzeroMagnitudexvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF21leastNonzeroMagnitudexvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "sign",
-          "printedName": "sign",
-          "declKind": "Var",
-          "usr": "s:SF4signs17FloatingPointSignOvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "FloatingPointSign",
-              "printedName": "FloatingPointSign",
-              "usr": "s:s17FloatingPointSignO"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF4signs17FloatingPointSignOvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "FloatingPointSign",
-                  "printedName": "FloatingPointSign",
-                  "usr": "s:s17FloatingPointSignO"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "exponent",
-          "printedName": "exponent",
-          "declKind": "Var",
-          "usr": "s:SF8exponent8ExponentQzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Exponent"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF8exponent8ExponentQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Exponent"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "significand",
-          "printedName": "significand",
-          "declKind": "Var",
-          "usr": "s:SF11significandxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF11significandxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "negate",
-          "printedName": "negate()",
-          "declKind": "Func",
-          "usr": "s:SF6negateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "remainder",
-          "printedName": "remainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:SF9remainder10dividingByxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DynamicSelf",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formRemainder",
-          "printedName": "formRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:SF13formRemainder10dividingByyx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "truncatingRemainder",
-          "printedName": "truncatingRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:SF19truncatingRemainder10dividingByxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DynamicSelf",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formTruncatingRemainder",
-          "printedName": "formTruncatingRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:SF23formTruncatingRemainder10dividingByyx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "squareRoot",
-          "printedName": "squareRoot()",
-          "declKind": "Func",
-          "usr": "s:SF10squareRootxyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DynamicSelf",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formSquareRoot",
-          "printedName": "formSquareRoot()",
-          "declKind": "Func",
-          "usr": "s:SF14formSquareRootyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "addingProduct",
-          "printedName": "addingProduct(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SF13addingProductyxx_xtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DynamicSelf",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "addProduct",
-          "printedName": "addProduct(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SF10addProductyyx_xtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "minimum",
-          "printedName": "minimum(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SF7minimumyxx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DynamicSelf",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "maximum",
-          "printedName": "maximum(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SF7maximumyxx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DynamicSelf",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "minimumMagnitude",
-          "printedName": "minimumMagnitude(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SF16minimumMagnitudeyxx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DynamicSelf",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "maximumMagnitude",
-          "printedName": "maximumMagnitude(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SF16maximumMagnitudeyxx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DynamicSelf",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "rounded",
-          "printedName": "rounded(_:)",
-          "declKind": "Func",
-          "usr": "s:SF7roundedyxs25FloatingPointRoundingRuleOF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DynamicSelf",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "FloatingPointRoundingRule",
-              "printedName": "FloatingPointRoundingRule",
-              "usr": "s:s25FloatingPointRoundingRuleO"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "round",
-          "printedName": "round(_:)",
-          "declKind": "Func",
-          "usr": "s:SF5roundyys25FloatingPointRoundingRuleOF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "FloatingPointRoundingRule",
-              "printedName": "FloatingPointRoundingRule",
-              "usr": "s:s25FloatingPointRoundingRuleO"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "nextUp",
-          "printedName": "nextUp",
-          "declKind": "Var",
-          "usr": "s:SF6nextUpxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF6nextUpxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "nextDown",
-          "printedName": "nextDown",
-          "declKind": "Var",
-          "usr": "s:SF8nextDownxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF8nextDownxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isEqual",
-          "printedName": "isEqual(to:)",
-          "declKind": "Func",
-          "usr": "s:SF7isEqual2toSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isLess",
-          "printedName": "isLess(than:)",
-          "declKind": "Func",
-          "usr": "s:SF6isLess4thanSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isLessThanOrEqualTo",
-          "printedName": "isLessThanOrEqualTo(_:)",
-          "declKind": "Func",
-          "usr": "s:SF19isLessThanOrEqualToySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isTotallyOrdered",
-          "printedName": "isTotallyOrdered(belowOrEqualTo:)",
-          "declKind": "Func",
-          "usr": "s:SF16isTotallyOrdered14belowOrEqualToSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isNormal",
-          "printedName": "isNormal",
-          "declKind": "Var",
-          "usr": "s:SF8isNormalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF8isNormalSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isFinite",
-          "printedName": "isFinite",
-          "declKind": "Var",
-          "usr": "s:SF8isFiniteSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF8isFiniteSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isZero",
-          "printedName": "isZero",
-          "declKind": "Var",
-          "usr": "s:SF6isZeroSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF6isZeroSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isSubnormal",
-          "printedName": "isSubnormal",
-          "declKind": "Var",
-          "usr": "s:SF11isSubnormalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF11isSubnormalSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isInfinite",
-          "printedName": "isInfinite",
-          "declKind": "Var",
-          "usr": "s:SF10isInfiniteSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF10isInfiniteSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isNaN",
-          "printedName": "isNaN",
-          "declKind": "Var",
-          "usr": "s:SF5isNaNSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF5isNaNSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isSignalingNaN",
-          "printedName": "isSignalingNaN",
-          "declKind": "Var",
-          "usr": "s:SF14isSignalingNaNSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF14isSignalingNaNSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "floatingPointClass",
-          "printedName": "floatingPointClass",
-          "declKind": "Var",
-          "usr": "s:SF18floatingPointClasss08FloatingB14ClassificationOvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "FloatingPointClassification",
-              "printedName": "FloatingPointClassification",
-              "usr": "s:s27FloatingPointClassificationO"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF18floatingPointClasss08FloatingB14ClassificationOvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "FloatingPointClassification",
-                  "printedName": "FloatingPointClassification",
-                  "usr": "s:s27FloatingPointClassificationO"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "isCanonical",
-          "printedName": "isCanonical",
-          "declKind": "Var",
-          "usr": "s:SF11isCanonicalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SF11isCanonicalSbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "ulpOfOne",
-          "printedName": "ulpOfOne",
-          "declKind": "Var",
-          "usr": "s:SFsE8ulpOfOnexvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SFsE8ulpOfOnexvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "rounded",
-          "printedName": "rounded(_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE7roundedyxs25FloatingPointRoundingRuleOF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "FloatingPointRoundingRule",
-              "printedName": "FloatingPointRoundingRule",
-              "usr": "s:s25FloatingPointRoundingRuleO"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "rounded",
-          "printedName": "rounded()",
-          "declKind": "Func",
-          "usr": "s:SFsE7roundedxyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "round",
-          "printedName": "round()",
-          "declKind": "Func",
-          "usr": "s:SFsE5roundyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "nextDown",
-          "printedName": "nextDown",
-          "declKind": "Var",
-          "usr": "s:SFsE8nextDownxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SFsE8nextDownxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "truncatingRemainder",
-          "printedName": "truncatingRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:SFsE19truncatingRemainder10dividingByxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "remainder",
-          "printedName": "remainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:SFsE9remainder10dividingByxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "squareRoot",
-          "printedName": "squareRoot()",
-          "declKind": "Func",
-          "usr": "s:SFsE10squareRootxyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "addingProduct",
-          "printedName": "addingProduct(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE13addingProductyxx_xtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "minimum",
-          "printedName": "minimum(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE7minimumyxx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "maximum",
-          "printedName": "maximum(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE7maximumyxx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "minimumMagnitude",
-          "printedName": "minimumMagnitude(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE16minimumMagnitudeyxx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "maximumMagnitude",
-          "printedName": "maximumMagnitude(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE16maximumMagnitudeyxx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "floatingPointClass",
-          "printedName": "floatingPointClass",
-          "declKind": "Var",
-          "usr": "s:SFsE18floatingPointClasss08FloatingB14ClassificationOvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "FloatingPointClassification",
-              "printedName": "FloatingPointClassification",
-              "usr": "s:s27FloatingPointClassificationO"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SFsE18floatingPointClasss08FloatingB14ClassificationOvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FloatingPoint>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "FloatingPointClassification",
-                  "printedName": "FloatingPointClassification",
-                  "usr": "s:s27FloatingPointClassificationO"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "negated",
-          "printedName": "negated()",
-          "declKind": "Func",
-          "usr": "s:SFsE7negatedxyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "adding",
-          "printedName": "adding(_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE6addingyxxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "add",
-          "printedName": "add(_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE3addyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "subtracting",
-          "printedName": "subtracting(_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE11subtractingyxxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "subtract",
-          "printedName": "subtract(_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE8subtractyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "multiplied",
-          "printedName": "multiplied(by:)",
-          "declKind": "Func",
-          "usr": "s:SFsE10multiplied2byxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "multiply",
-          "printedName": "multiply(by:)",
-          "declKind": "Func",
-          "usr": "s:SFsE8multiply2byyx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "divided",
-          "printedName": "divided(by:)",
-          "declKind": "Func",
-          "usr": "s:SFsE7divided2byxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "divide",
-          "printedName": "divide(by:)",
-          "declKind": "Func",
-          "usr": "s:SFsE6divide2byyx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "mutating": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "abs",
-          "printedName": "abs(_:)",
-          "declKind": "Func",
-          "usr": "s:SFsE3absyxxFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FloatingPoint>",
-          "static": true,
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        }
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "FloatingPointSign",
       "printedName": "FloatingPointSign",
-      "declKind": "Enum",
-      "usr": "s:s17FloatingPointSignO",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable",
-        "RawRepresentable"
-      ],
-      "enumRawTypeName": "Int",
-      "declAttributes": [
-        "Frozen"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "plus",
           "printedName": "plus",
-          "declKind": "EnumElement",
-          "usr": "s:s17FloatingPointSignO4plusyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35388,16 +37369,16 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s17FloatingPointSignO4plusyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0
         },
         {
           "kind": "Var",
           "name": "minus",
           "printedName": "minus",
-          "declKind": "EnumElement",
-          "usr": "s:s17FloatingPointSignO5minusyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35432,25 +37413,21 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s17FloatingPointSignO5minusyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(rawValue:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FloatingPointSignO8rawValueABSgSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "FloatingPointSign?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -35458,7 +37435,8 @@
                   "printedName": "FloatingPointSign",
                   "usr": "s:s17FloatingPointSignO"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -35466,19 +37444,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FloatingPointSignO8rawValueABSgSi_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "rawValue",
           "printedName": "rawValue",
-          "declKind": "Var",
-          "usr": "s:s17FloatingPointSignO8rawValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -35490,10 +37467,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FloatingPointSignO8rawValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -35501,18 +37474,55 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FloatingPointSignO8rawValueSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FloatingPointSignO8rawValueSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointSign",
+              "printedName": "FloatingPointSign",
+              "usr": "s:s17FloatingPointSignO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointSign",
+              "printedName": "FloatingPointSign",
+              "usr": "s:s17FloatingPointSignO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FloatingPointSignO2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "RawValue",
           "printedName": "RawValue",
-          "declKind": "TypeAlias",
-          "usr": "s:s17FloatingPointSignO8RawValuea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -35520,16 +37530,16 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s17FloatingPointSignO8RawValuea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s17FloatingPointSignO9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -35541,10 +37551,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FloatingPointSignO9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -35552,18 +37558,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FloatingPointSignO9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FloatingPointSignO9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s17FloatingPointSignO4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -35576,34 +37586,35 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FloatingPointSignO4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "implicit": true
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s17FloatingPointSignO",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Frozen"
+      ],
+      "enumRawTypeName": "Int",
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable",
+        "RawRepresentable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "FloatingPointClassification",
       "printedName": "FloatingPointClassification",
-      "declKind": "Enum",
-      "usr": "s:s27FloatingPointClassificationO",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable"
-      ],
-      "declAttributes": [
-        "Frozen"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "signalingNaN",
           "printedName": "signalingNaN",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO12signalingNaNyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35638,16 +37649,16 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO12signalingNaNyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0
         },
         {
           "kind": "Var",
           "name": "quietNaN",
           "printedName": "quietNaN",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO8quietNaNyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35682,16 +37693,16 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO8quietNaNyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1
         },
         {
           "kind": "Var",
           "name": "negativeInfinity",
           "printedName": "negativeInfinity",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO16negativeInfinityyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35726,16 +37737,16 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO16negativeInfinityyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 2
         },
         {
           "kind": "Var",
           "name": "negativeNormal",
           "printedName": "negativeNormal",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO14negativeNormalyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35770,16 +37781,16 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO14negativeNormalyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 3
         },
         {
           "kind": "Var",
           "name": "negativeSubnormal",
           "printedName": "negativeSubnormal",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO17negativeSubnormalyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35814,16 +37825,16 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO17negativeSubnormalyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 4
         },
         {
           "kind": "Var",
           "name": "negativeZero",
           "printedName": "negativeZero",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO12negativeZeroyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35858,16 +37869,16 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO12negativeZeroyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 5
         },
         {
           "kind": "Var",
           "name": "positiveZero",
           "printedName": "positiveZero",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO12positiveZeroyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35902,16 +37913,16 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO12positiveZeroyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 6
         },
         {
           "kind": "Var",
           "name": "positiveSubnormal",
           "printedName": "positiveSubnormal",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO17positiveSubnormalyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35946,16 +37957,16 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO17positiveSubnormalyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 7
         },
         {
           "kind": "Var",
           "name": "positiveNormal",
           "printedName": "positiveNormal",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO14positiveNormalyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -35990,16 +38001,16 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO14positiveNormalyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 8
         },
         {
           "kind": "Var",
           "name": "positiveInfinity",
           "printedName": "positiveInfinity",
-          "declKind": "EnumElement",
-          "usr": "s:s27FloatingPointClassificationO16positiveInfinityyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -36034,16 +38045,49 @@
                 }
               ]
             }
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s27FloatingPointClassificationO16positiveInfinityyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 9
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointClassification",
+              "printedName": "FloatingPointClassification",
+              "usr": "s:s27FloatingPointClassificationO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointClassification",
+              "printedName": "FloatingPointClassification",
+              "usr": "s:s27FloatingPointClassificationO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s27FloatingPointClassificationO2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "implicit": true,
+          "declAttributes": [
+            "Infix"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s27FloatingPointClassificationO9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -36055,10 +38099,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s27FloatingPointClassificationO9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -36066,18 +38106,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s27FloatingPointClassificationO9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s27FloatingPointClassificationO9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s27FloatingPointClassificationO4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -36090,31 +38134,33 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s27FloatingPointClassificationO4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "implicit": true
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s27FloatingPointClassificationO",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Frozen"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "FloatingPointRoundingRule",
       "printedName": "FloatingPointRoundingRule",
-      "declKind": "Enum",
-      "usr": "s:s25FloatingPointRoundingRuleO",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "toNearestOrAwayFromZero",
           "printedName": "toNearestOrAwayFromZero",
-          "declKind": "EnumElement",
-          "usr": "s:s25FloatingPointRoundingRuleO23toNearestOrAwayFromZeroyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -36149,16 +38195,15 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s25FloatingPointRoundingRuleO23toNearestOrAwayFromZeroyA2BmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "toNearestOrEven",
           "printedName": "toNearestOrEven",
-          "declKind": "EnumElement",
-          "usr": "s:s25FloatingPointRoundingRuleO15toNearestOrEvenyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -36193,16 +38238,15 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s25FloatingPointRoundingRuleO15toNearestOrEvenyA2BmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "up",
           "printedName": "up",
-          "declKind": "EnumElement",
-          "usr": "s:s25FloatingPointRoundingRuleO2upyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -36237,16 +38281,15 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s25FloatingPointRoundingRuleO2upyA2BmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "down",
           "printedName": "down",
-          "declKind": "EnumElement",
-          "usr": "s:s25FloatingPointRoundingRuleO4downyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -36281,16 +38324,15 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s25FloatingPointRoundingRuleO4downyA2BmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "towardZero",
           "printedName": "towardZero",
-          "declKind": "EnumElement",
-          "usr": "s:s25FloatingPointRoundingRuleO10towardZeroyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -36325,16 +38367,15 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s25FloatingPointRoundingRuleO10towardZeroyA2BmF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "awayFromZero",
           "printedName": "awayFromZero",
-          "declKind": "EnumElement",
-          "usr": "s:s25FloatingPointRoundingRuleO12awayFromZeroyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -36369,16 +38410,48 @@
                 }
               ]
             }
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s25FloatingPointRoundingRuleO12awayFromZeroyA2BmF",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointRoundingRule",
+              "printedName": "FloatingPointRoundingRule",
+              "usr": "s:s25FloatingPointRoundingRuleO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "FloatingPointRoundingRule",
+              "printedName": "FloatingPointRoundingRule",
+              "usr": "s:s25FloatingPointRoundingRuleO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25FloatingPointRoundingRuleO2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "implicit": true,
+          "declAttributes": [
+            "Infix"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s25FloatingPointRoundingRuleO9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -36390,10 +38463,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s25FloatingPointRoundingRuleO9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -36401,18 +38470,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25FloatingPointRoundingRuleO9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s25FloatingPointRoundingRuleO9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s25FloatingPointRoundingRuleO4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -36425,40 +38498,48 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s25FloatingPointRoundingRuleO4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "implicit": true
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s25FloatingPointRoundingRuleO",
+      "moduleName": "Swift",
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "BinaryFloatingPoint",
       "printedName": "BinaryFloatingPoint",
-      "declKind": "Protocol",
-      "usr": "s:SB",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : ExpressibleByFloatLiteral, Self : FloatingPoint, Self.RawExponent : UnsignedInteger, Self.RawSignificand : UnsignedInteger>",
-      "conformingProtocols": [
-        "FloatingPoint",
-        "ExpressibleByFloatLiteral",
-        "SignedNumeric",
-        "Strideable",
-        "Hashable",
-        "Numeric",
-        "Comparable",
-        "Equatable",
-        "ExpressibleByIntegerLiteral"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "RawSignificand",
+          "printedName": "RawSignificand",
+          "declKind": "AssociatedType",
+          "usr": "s:SB14RawSignificandQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "RawExponent",
+          "printedName": "RawExponent",
+          "declKind": "AssociatedType",
+          "usr": "s:SB11RawExponentQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(sign:exponentBitPattern:significandBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:SB4sign18exponentBitPattern011significandcD0xs17FloatingPointSignO_11RawExponentQz0I11SignificandQztcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryFloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -36481,17 +38562,17 @@
               "name": "DependentMember",
               "printedName": "Self.RawSignificand"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SB4sign18exponentBitPattern011significandcD0xs17FloatingPointSignO_11RawExponentQz0I11SignificandQztcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryFloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SByxSfcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryFloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -36504,17 +38585,17 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SByxSfcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryFloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SByxSdcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryFloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -36527,17 +38608,17 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SByxSdcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryFloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SByxs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryFloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -36550,17 +38631,17 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SByxs7Float80Vcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryFloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SByxqd__cSBRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Source where Self : BinaryFloatingPoint, Source : BinaryFloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -36572,47 +38653,47 @@
               "name": "GenericTypeParam",
               "printedName": "Source"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SByxqd__cSBRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Source where Self : BinaryFloatingPoint, Source : BinaryFloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:SB7exactlyxSgqd___tcSBRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Source where Self : BinaryFloatingPoint, Source : BinaryFloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Source"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SB7exactlyxSgqd___tcSBRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Source where Self : BinaryFloatingPoint, Source : BinaryFloatingPoint>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "exponentBitCount",
           "printedName": "exponentBitCount",
-          "declKind": "Var",
-          "usr": "s:SB16exponentBitCountSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -36624,12 +38705,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SB16exponentBitCountSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryFloatingPoint>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -36637,19 +38712,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SB16exponentBitCountSivgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : BinaryFloatingPoint>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SB16exponentBitCountSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "significandBitCount",
           "printedName": "significandBitCount",
-          "declKind": "Var",
-          "usr": "s:SB19significandBitCountSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -36661,12 +38741,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SB19significandBitCountSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryFloatingPoint>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -36674,18 +38748,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SB19significandBitCountSivgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : BinaryFloatingPoint>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SB19significandBitCountSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "exponentBitPattern",
           "printedName": "exponentBitPattern",
-          "declKind": "Var",
-          "usr": "s:SB18exponentBitPattern11RawExponentQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -36696,29 +38776,28 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SB18exponentBitPattern11RawExponentQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryFloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.RawExponent"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SB18exponentBitPattern11RawExponentQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : BinaryFloatingPoint>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SB18exponentBitPattern11RawExponentQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "significandBitPattern",
           "printedName": "significandBitPattern",
-          "declKind": "Var",
-          "usr": "s:SB21significandBitPattern14RawSignificandQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -36729,29 +38808,28 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SB21significandBitPattern14RawSignificandQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryFloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.RawSignificand"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SB21significandBitPattern14RawSignificandQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : BinaryFloatingPoint>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SB21significandBitPattern14RawSignificandQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "binade",
           "printedName": "binade",
-          "declKind": "Var",
-          "usr": "s:SB6binadexvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -36762,29 +38840,28 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SB6binadexvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryFloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SB6binadexvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : BinaryFloatingPoint>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SB6binadexvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "significandWidth",
           "printedName": "significandWidth",
-          "declKind": "Var",
-          "usr": "s:SB16significandWidthSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -36796,11 +38873,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SB16significandWidthSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryFloatingPoint>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -36808,19 +38880,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SB16significandWidthSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : BinaryFloatingPoint>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SB16significandWidthSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "radix",
           "printedName": "radix",
-          "declKind": "Var",
-          "usr": "s:SBsE5radixSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -36832,12 +38907,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SBsE5radixSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryFloatingPoint>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -36845,52 +38914,52 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SBsE5radixSivgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : BinaryFloatingPoint>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SBsE5radixSivpZ",
+          "moduleName": "Swift",
+          "static": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(signOf:magnitudeOf:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SBsE6signOf09magnitudeB0xx_xtcfc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : BinaryFloatingPoint>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SBsEyxqd__cSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Source where Self : BinaryFloatingPoint, Source : BinaryInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -36902,111 +38971,51 @@
               "name": "GenericTypeParam",
               "printedName": "Source"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:SBsE7exactlyxSgqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Source where Self : BinaryFloatingPoint, Source : BinaryInteger>",
-          "declAttributes": [
-            "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Source"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
           "declKind": "Constructor",
           "usr": "s:SBsEyxqd__cSBRd__lufc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, Source where Self : BinaryFloatingPoint, Source : BinaryFloatingPoint>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Source"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:SBsE7exactlyxSgqd___tcSBRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Source where Self : BinaryFloatingPoint, Source : BinaryFloatingPoint>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Source"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SBsE7exactlyxSgqd___tcSBRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Source where Self : BinaryFloatingPoint, Source : BinaryFloatingPoint>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "isTotallyOrdered",
           "printedName": "isTotallyOrdered(belowOrEqualTo:)",
-          "declKind": "Func",
-          "usr": "s:SBsE16isTotallyOrdered14belowOrEqualToSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryFloatingPoint>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37019,60 +39028,113 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SBsE16isTotallyOrdered14belowOrEqualToSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryFloatingPoint>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Source"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlEyxqd__cSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Source where Self : BinaryFloatingPoint, Source : BinaryInteger, Self.RawSignificand : FixedWidthInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Self?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Source"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlE7exactlyxSgqd___tcSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Source where Self : BinaryFloatingPoint, Source : BinaryInteger, Self.RawSignificand : FixedWidthInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "random",
           "printedName": "random(in:using:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Self>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "T"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlE6random2in5usingxSnyxG_qd__ztSGRd__lFZ",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : BinaryFloatingPoint, T : RandomNumberGenerator, Self.RawSignificand : FixedWidthInteger>",
           "static": true,
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Self>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
           ]
         },
         {
           "kind": "Function",
           "name": "random",
           "printedName": "random(in:)",
-          "declKind": "Func",
-          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlE6random2inxSnyxG_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryFloatingPoint, Self.RawSignificand : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37083,30 +39145,29 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Self>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlE6random2inxSnyxG_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryFloatingPoint, Self.RawSignificand : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "random",
           "printedName": "random(in:using:)",
-          "declKind": "Func",
-          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlE6random2in5usingxSNyxG_qd__ztSGRd__lFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : BinaryFloatingPoint, T : RandomNumberGenerator, Self.RawSignificand : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37117,35 +39178,34 @@
               "kind": "TypeNominal",
               "name": "ClosedRange",
               "printedName": "ClosedRange<Self>",
-              "usr": "s:SN",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:SN"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlE6random2in5usingxSNyxG_qd__ztSGRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : BinaryFloatingPoint, T : RandomNumberGenerator, Self.RawSignificand : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "random",
           "printedName": "random(in:)",
-          "declKind": "Func",
-          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlE6random2inxSNyxG_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryFloatingPoint, Self.RawSignificand : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37156,67 +39216,51 @@
               "kind": "TypeNominal",
               "name": "ClosedRange",
               "printedName": "ClosedRange<Self>",
-              "usr": "s:SN",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:SN"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SBss17FixedWidthInteger14RawSignificandRpzrlE6random2inxSNyxG_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryFloatingPoint, Self.RawSignificand : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SB",
+      "moduleName": "Swift",
+      "genericSig": "<Self : ExpressibleByFloatLiteral, Self : FloatingPoint, Self.RawExponent : UnsignedInteger, Self.RawSignificand : UnsignedInteger>",
+      "conformingProtocols": [
+        "FloatingPoint",
+        "ExpressibleByFloatLiteral",
+        "SignedNumeric",
+        "Strideable",
+        "Hashable",
+        "Numeric",
+        "Comparable",
+        "Equatable",
+        "ExpressibleByIntegerLiteral"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Float",
       "printedName": "Float",
-      "declKind": "Struct",
-      "usr": "s:Sf",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Decodable",
-        "Encodable",
-        "LosslessStringConvertible",
-        "CustomStringConvertible",
-        "CustomDebugStringConvertible",
-        "BinaryFloatingPoint",
-        "FloatingPoint",
-        "ExpressibleByFloatLiteral",
-        "SignedNumeric",
-        "Numeric",
-        "_ExpressibleByBuiltinIntegerLiteral",
-        "ExpressibleByIntegerLiteral",
-        "_ExpressibleByBuiltinFloatLiteral",
-        "Hashable",
-        "Equatable",
-        "_HasCustomAnyHashableRepresentation",
-        "Strideable",
-        "Comparable",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "_CVarArgPassedAsDouble",
-        "_CVarArgAligned",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:S2fycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37224,20 +39268,18 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:S2fycfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf4fromSfs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37251,20 +39293,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf4fromSfs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:Sf6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37277,26 +39315,21 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfSgxcSyRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : StringProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Float?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -37304,26 +39337,27 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SfySfSgxcSyRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<S where S : StringProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:Sf11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37335,10 +39369,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -37346,18 +39376,23 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf11descriptionSSvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Sf16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -37369,10 +39404,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -37380,18 +39411,20 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf16debugDescriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "Magnitude",
           "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:Sf9Magnitudea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -37399,16 +39432,15 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sf9Magnitudea",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "Exponent",
           "printedName": "Exponent",
-          "declKind": "TypeAlias",
-          "usr": "s:Sf8Exponenta",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -37416,16 +39448,15 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sf8Exponenta",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "RawSignificand",
           "printedName": "RawSignificand",
-          "declKind": "TypeAlias",
-          "usr": "s:Sf14RawSignificanda",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -37433,20 +39464,15 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sf14RawSignificanda",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "exponentBitCount",
           "printedName": "exponentBitCount",
-          "declKind": "Var",
-          "usr": "s:Sf16exponentBitCountSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37458,11 +39484,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf16exponentBitCountSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -37470,22 +39491,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf16exponentBitCountSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf16exponentBitCountSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "significandBitCount",
           "printedName": "significandBitCount",
-          "declKind": "Var",
-          "usr": "s:Sf19significandBitCountSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37497,11 +39521,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf19significandBitCountSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -37509,21 +39528,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf19significandBitCountSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf19significandBitCountSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "bitPattern",
           "printedName": "bitPattern",
-          "declKind": "Var",
-          "usr": "s:Sf10bitPatterns6UInt32Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37535,10 +39558,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf10bitPatterns6UInt32Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -37546,21 +39565,23 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf10bitPatterns6UInt32Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf10bitPatterns6UInt32Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf10bitPatternSfs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37574,19 +39595,18 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf10bitPatternSfs6UInt32V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "sign",
           "printedName": "sign",
-          "declKind": "Var",
-          "usr": "s:Sf4signs17FloatingPointSignOvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37598,10 +39618,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf4signs17FloatingPointSignOvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -37609,21 +39625,23 @@
                   "printedName": "FloatingPointSign",
                   "usr": "s:s17FloatingPointSignO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf4signs17FloatingPointSignOvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf4signs17FloatingPointSignOvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "exponentBitPattern",
           "printedName": "exponentBitPattern",
-          "declKind": "Var",
-          "usr": "s:Sf18exponentBitPatternSuvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37635,10 +39653,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf18exponentBitPatternSuvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -37646,21 +39660,23 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf18exponentBitPatternSuvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf18exponentBitPatternSuvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "significandBitPattern",
           "printedName": "significandBitPattern",
-          "declKind": "Var",
-          "usr": "s:Sf21significandBitPatterns6UInt32Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37672,10 +39688,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf21significandBitPatterns6UInt32Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -37683,21 +39695,23 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf21significandBitPatterns6UInt32Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf21significandBitPatterns6UInt32Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(sign:exponentBitPattern:significandBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf4sign18exponentBitPattern011significandcD0Sfs17FloatingPointSignO_Sus6UInt32Vtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37723,19 +39737,18 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf4sign18exponentBitPattern011significandcD0Sfs17FloatingPointSignO_Sus6UInt32Vtcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "isCanonical",
           "printedName": "isCanonical",
-          "declKind": "Var",
-          "usr": "s:Sf11isCanonicalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37747,10 +39760,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf11isCanonicalSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -37758,22 +39767,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf11isCanonicalSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf11isCanonicalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "infinity",
           "printedName": "infinity",
-          "declKind": "Var",
-          "usr": "s:Sf8infinitySfvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37785,11 +39795,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf8infinitySfvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -37797,22 +39802,25 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf8infinitySfvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf8infinitySfvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "nan",
           "printedName": "nan",
-          "declKind": "Var",
-          "usr": "s:Sf3nanSfvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37824,11 +39832,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf3nanSfvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -37836,22 +39839,25 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf3nanSfvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf3nanSfvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "signalingNaN",
           "printedName": "signalingNaN",
-          "declKind": "Var",
-          "usr": "s:Sf12signalingNaNSfvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37863,11 +39869,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf12signalingNaNSfvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -37875,22 +39876,25 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf12signalingNaNSfvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf12signalingNaNSfvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "greatestFiniteMagnitude",
           "printedName": "greatestFiniteMagnitude",
-          "declKind": "Var",
-          "usr": "s:Sf23greatestFiniteMagnitudeSfvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37902,11 +39906,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf23greatestFiniteMagnitudeSfvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -37914,22 +39913,25 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf23greatestFiniteMagnitudeSfvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf23greatestFiniteMagnitudeSfvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "pi",
           "printedName": "pi",
-          "declKind": "Var",
-          "usr": "s:Sf2piSfvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37941,11 +39943,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf2piSfvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -37953,21 +39950,25 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf2piSfvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf2piSfvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "ulp",
           "printedName": "ulp",
-          "declKind": "Var",
-          "usr": "s:Sf3ulpSfvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -37979,10 +39980,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf3ulpSfvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -37990,22 +39987,23 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf3ulpSfvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf3ulpSfvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "leastNormalMagnitude",
           "printedName": "leastNormalMagnitude",
-          "declKind": "Var",
-          "usr": "s:Sf20leastNormalMagnitudeSfvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38017,11 +40015,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf20leastNormalMagnitudeSfvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -38029,22 +40022,25 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf20leastNormalMagnitudeSfvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf20leastNormalMagnitudeSfvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "leastNonzeroMagnitude",
           "printedName": "leastNonzeroMagnitude",
-          "declKind": "Var",
-          "usr": "s:Sf21leastNonzeroMagnitudeSfvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38056,11 +40052,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf21leastNonzeroMagnitudeSfvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -38068,22 +40059,25 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf21leastNonzeroMagnitudeSfvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf21leastNonzeroMagnitudeSfvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "ulpOfOne",
           "printedName": "ulpOfOne",
-          "declKind": "Var",
-          "usr": "s:Sf8ulpOfOneSfvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38095,11 +40089,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf8ulpOfOneSfvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -38107,21 +40096,25 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf8ulpOfOneSfvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf8ulpOfOneSfvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "exponent",
           "printedName": "exponent",
-          "declKind": "Var",
-          "usr": "s:Sf8exponentSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38133,10 +40126,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf8exponentSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -38144,21 +40133,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf8exponentSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf8exponentSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "significand",
           "printedName": "significand",
-          "declKind": "Var",
-          "usr": "s:Sf11significandSfvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38170,10 +40161,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf11significandSfvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -38181,21 +40168,23 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf11significandSfvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf11significandSfvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(sign:exponent:significand:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf4sign8exponent11significandSfs17FloatingPointSignO_SiSftcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38221,19 +40210,18 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf4sign8exponent11significandSfs17FloatingPointSignO_SiSftcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(nan:signaling:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf3nan9signalingSfs6UInt32V_Sbtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38260,19 +40248,18 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf3nan9signalingSfs6UInt32V_Sbtcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "nextUp",
           "printedName": "nextUp",
-          "declKind": "Var",
-          "usr": "s:Sf6nextUpSfvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38284,10 +40271,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf6nextUpSfvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -38295,22 +40278,23 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf6nextUpSfvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf6nextUpSfvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "round",
           "printedName": "round(_:)",
-          "declKind": "Func",
-          "usr": "s:Sf5roundyys25FloatingPointRoundingRuleOF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38323,40 +40307,162 @@
               "printedName": "FloatingPointRoundingRule",
               "usr": "s:s25FloatingPointRoundingRuleO"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf5roundyys25FloatingPointRoundingRuleOF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "negate",
           "printedName": "negate()",
-          "declKind": "Func",
-          "usr": "s:Sf6negateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf6negateyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf2peoiyySfz_SftFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf2seoiyySfz_SftFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf2meoiyySfz_SftFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf2deoiyySfz_SftFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "formRemainder",
           "printedName": "formRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:Sf13formRemainder10dividingByySf_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38369,20 +40475,19 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf13formRemainder10dividingByySf_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "formTruncatingRemainder",
           "printedName": "formTruncatingRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:Sf23formTruncatingRemainder10dividingByySf_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38395,40 +40500,38 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf23formTruncatingRemainder10dividingByySf_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "formSquareRoot",
           "printedName": "formSquareRoot()",
-          "declKind": "Func",
-          "usr": "s:Sf14formSquareRootyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf14formSquareRootyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "addProduct",
           "printedName": "addProduct(_:_:)",
-          "declKind": "Func",
-          "usr": "s:Sf10addProductyySf_SftF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38447,19 +40550,19 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf10addProductyySf_SftF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "isEqual",
           "printedName": "isEqual(to:)",
-          "declKind": "Func",
-          "usr": "s:Sf7isEqual2toSbSf_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38473,19 +40576,18 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf7isEqual2toSbSf_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "isLess",
           "printedName": "isLess(than:)",
-          "declKind": "Func",
-          "usr": "s:Sf6isLess4thanSbSf_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38499,19 +40601,18 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf6isLess4thanSbSf_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "isLessThanOrEqualTo",
           "printedName": "isLessThanOrEqualTo(_:)",
-          "declKind": "Func",
-          "usr": "s:Sf19isLessThanOrEqualToySbSfF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38525,19 +40626,18 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf19isLessThanOrEqualToySbSfF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isNormal",
           "printedName": "isNormal",
-          "declKind": "Var",
-          "usr": "s:Sf8isNormalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38549,10 +40649,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf8isNormalSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -38560,21 +40656,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf8isNormalSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf8isNormalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isFinite",
           "printedName": "isFinite",
-          "declKind": "Var",
-          "usr": "s:Sf8isFiniteSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38586,10 +40684,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf8isFiniteSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -38597,21 +40691,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf8isFiniteSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf8isFiniteSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isZero",
           "printedName": "isZero",
-          "declKind": "Var",
-          "usr": "s:Sf6isZeroSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38623,10 +40719,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf6isZeroSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -38634,21 +40726,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf6isZeroSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf6isZeroSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isSubnormal",
           "printedName": "isSubnormal",
-          "declKind": "Var",
-          "usr": "s:Sf11isSubnormalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38660,10 +40754,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf11isSubnormalSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -38671,21 +40761,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf11isSubnormalSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf11isSubnormalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isInfinite",
           "printedName": "isInfinite",
-          "declKind": "Var",
-          "usr": "s:Sf10isInfiniteSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38697,10 +40789,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf10isInfiniteSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -38708,21 +40796,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf10isInfiniteSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf10isInfiniteSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isNaN",
           "printedName": "isNaN",
-          "declKind": "Var",
-          "usr": "s:Sf5isNaNSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38734,10 +40824,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf5isNaNSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -38745,21 +40831,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf5isNaNSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf5isNaNSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isSignalingNaN",
           "printedName": "isSignalingNaN",
-          "declKind": "Var",
-          "usr": "s:Sf14isSignalingNaNSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38771,10 +40859,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf14isSignalingNaNSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -38782,21 +40866,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf14isSignalingNaNSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf14isSignalingNaNSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "binade",
           "printedName": "binade",
-          "declKind": "Var",
-          "usr": "s:Sf6binadeSfvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38808,10 +40894,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf6binadeSfvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -38819,21 +40901,23 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf6binadeSfvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf6binadeSfvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "significandWidth",
           "printedName": "significandWidth",
-          "declKind": "Var",
-          "usr": "s:Sf16significandWidthSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38845,10 +40929,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf16significandWidthSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -38856,21 +40936,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf16significandWidthSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf16significandWidthSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(floatLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf12floatLiteralS2f_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38884,16 +40966,18 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf12floatLiteralS2f_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "FloatLiteralType",
           "printedName": "FloatLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Sf16FloatLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -38901,16 +40985,16 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sf16FloatLiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "RawExponent",
           "printedName": "RawExponent",
-          "declKind": "TypeAlias",
-          "usr": "s:Sf11RawExponenta",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -38918,19 +41002,16 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sf11RawExponenta",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(integerLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf14integerLiteralSfs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38944,16 +41025,18 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf14integerLiteralSfs5Int64V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "IntegerLiteralType",
           "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Sf18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -38961,19 +41044,16 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sf18IntegerLiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:Sf4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -38986,16 +41066,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Sf9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -39007,10 +41089,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -39018,21 +41096,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:Sf9magnitudeSfvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -39044,32 +41123,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
               "declKind": "Accessor",
               "usr": "s:Sf9magnitudeSfvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs5UInt8Vcfc",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf9magnitudeSfvp",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -39079,59 +41156,24 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs5UInt8V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            }
+          "declKind": "Func",
+          "usr": "s:Sf1sopyS2fFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs4Int8Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -39141,488 +41183,22 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs4Int8V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs6UInt16Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs6UInt16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs5Int16Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs5Int16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs6UInt32Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs5Int32Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs5Int32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs6UInt64Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs5Int64Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfSucfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
           "declKind": "Constructor",
           "usr": "s:SfySfSicfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -39632,64 +41208,61 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "GenericTypeParam",
+              "printedName": "Source"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
+          "declKind": "Constructor",
+          "usr": "s:SfySfxcSzRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<Source where Source : BinaryInteger>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SfyS2fcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
+              "name": "Optional",
+              "printedName": "Float?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float",
+                  "printedName": "Float",
+                  "usr": "s:Sf"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -39697,87 +41270,49 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:Sf7exactlySfSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Inline",
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float",
-                  "printedName": "Float",
-                  "usr": "s:Sf"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SfySfSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Float?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -39785,7 +41320,8 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -39793,19 +41329,19 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf7exactlySfSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SfySfs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -39819,26 +41355,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SfySfs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sf7exactlySfSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Float?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -39846,7 +41379,8 @@
                   "printedName": "Float",
                   "usr": "s:Sf"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -39854,19 +41388,147 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sf7exactlySfSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf1poiyS2f_SftFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf1soiyS2f_SftFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf1moiyS2f_SftFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf1doiyS2f_SftFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(to:)",
-          "declKind": "Func",
-          "usr": "s:Sf8distance2toS2f_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -39880,19 +41542,18 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf8distance2toS2f_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "advanced",
           "printedName": "advanced(by:)",
-          "declKind": "Func",
-          "usr": "s:Sf8advanced2byS2f_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -39906,16 +41567,18 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sf8advanced2byS2f_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:Sf6Stridea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -39923,16 +41586,16 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sf6Stridea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Sf12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -39944,10 +41607,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -39955,23 +41614,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf12customMirrors0B0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf12customMirrors0B0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:Sf25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -39983,10 +41639,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sf25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -39994,23 +41646,30 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sf25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sf25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "Double",
-      "printedName": "Double",
+      ],
       "declKind": "Struct",
-      "usr": "s:Sd",
-      "location": "",
+      "usr": "s:Sf",
       "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
-        "Decodable",
         "Encodable",
+        "Decodable",
         "LosslessStringConvertible",
         "CustomStringConvertible",
         "CustomDebugStringConvertible",
@@ -40032,22 +41691,17 @@
         "_CVarArgPassedAsDouble",
         "_CVarArgAligned",
         "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Double",
+      "printedName": "Double",
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:S2dycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40055,20 +41709,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:S2dycfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd4fromSds7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40082,20 +41734,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd4fromSds7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:Sd6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40108,26 +41756,21 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySdSgxcSyRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : StringProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Double?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40135,26 +41778,27 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SdySdSgxcSyRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<S where S : StringProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:Sd11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40166,10 +41810,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40177,18 +41817,23 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd11descriptionSSvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Sd16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -40200,10 +41845,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40211,18 +41852,20 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd16debugDescriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "Magnitude",
           "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:Sd9Magnitudea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -40230,16 +41873,15 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sd9Magnitudea",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "Exponent",
           "printedName": "Exponent",
-          "declKind": "TypeAlias",
-          "usr": "s:Sd8Exponenta",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -40247,16 +41889,15 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sd8Exponenta",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "RawSignificand",
           "printedName": "RawSignificand",
-          "declKind": "TypeAlias",
-          "usr": "s:Sd14RawSignificanda",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -40264,20 +41905,15 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sd14RawSignificanda",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "exponentBitCount",
           "printedName": "exponentBitCount",
-          "declKind": "Var",
-          "usr": "s:Sd16exponentBitCountSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40289,11 +41925,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd16exponentBitCountSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40301,22 +41932,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd16exponentBitCountSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd16exponentBitCountSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "significandBitCount",
           "printedName": "significandBitCount",
-          "declKind": "Var",
-          "usr": "s:Sd19significandBitCountSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40328,11 +41962,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd19significandBitCountSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40340,21 +41969,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd19significandBitCountSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd19significandBitCountSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "bitPattern",
           "printedName": "bitPattern",
-          "declKind": "Var",
-          "usr": "s:Sd10bitPatterns6UInt64Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40366,10 +41999,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd10bitPatterns6UInt64Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40377,21 +42006,23 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd10bitPatterns6UInt64Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd10bitPatterns6UInt64Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd10bitPatternSds6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40405,19 +42036,18 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd10bitPatternSds6UInt64V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "sign",
           "printedName": "sign",
-          "declKind": "Var",
-          "usr": "s:Sd4signs17FloatingPointSignOvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40429,10 +42059,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd4signs17FloatingPointSignOvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40440,21 +42066,23 @@
                   "printedName": "FloatingPointSign",
                   "usr": "s:s17FloatingPointSignO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd4signs17FloatingPointSignOvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd4signs17FloatingPointSignOvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "exponentBitPattern",
           "printedName": "exponentBitPattern",
-          "declKind": "Var",
-          "usr": "s:Sd18exponentBitPatternSuvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40466,10 +42094,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd18exponentBitPatternSuvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40477,21 +42101,23 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd18exponentBitPatternSuvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd18exponentBitPatternSuvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "significandBitPattern",
           "printedName": "significandBitPattern",
-          "declKind": "Var",
-          "usr": "s:Sd21significandBitPatterns6UInt64Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40503,10 +42129,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd21significandBitPatterns6UInt64Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40514,21 +42136,23 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd21significandBitPatterns6UInt64Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd21significandBitPatterns6UInt64Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(sign:exponentBitPattern:significandBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd4sign18exponentBitPattern011significandcD0Sds17FloatingPointSignO_Sus6UInt64Vtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40554,19 +42178,18 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd4sign18exponentBitPattern011significandcD0Sds17FloatingPointSignO_Sus6UInt64Vtcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "isCanonical",
           "printedName": "isCanonical",
-          "declKind": "Var",
-          "usr": "s:Sd11isCanonicalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40578,10 +42201,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd11isCanonicalSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40589,22 +42208,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd11isCanonicalSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd11isCanonicalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "infinity",
           "printedName": "infinity",
-          "declKind": "Var",
-          "usr": "s:Sd8infinitySdvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40616,11 +42236,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd8infinitySdvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40628,22 +42243,25 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd8infinitySdvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd8infinitySdvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "nan",
           "printedName": "nan",
-          "declKind": "Var",
-          "usr": "s:Sd3nanSdvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40655,11 +42273,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd3nanSdvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40667,22 +42280,25 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd3nanSdvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd3nanSdvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "signalingNaN",
           "printedName": "signalingNaN",
-          "declKind": "Var",
-          "usr": "s:Sd12signalingNaNSdvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40694,11 +42310,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd12signalingNaNSdvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40706,22 +42317,25 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd12signalingNaNSdvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd12signalingNaNSdvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "greatestFiniteMagnitude",
           "printedName": "greatestFiniteMagnitude",
-          "declKind": "Var",
-          "usr": "s:Sd23greatestFiniteMagnitudeSdvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40733,11 +42347,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd23greatestFiniteMagnitudeSdvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40745,22 +42354,25 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd23greatestFiniteMagnitudeSdvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd23greatestFiniteMagnitudeSdvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "pi",
           "printedName": "pi",
-          "declKind": "Var",
-          "usr": "s:Sd2piSdvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40772,11 +42384,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd2piSdvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40784,21 +42391,25 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd2piSdvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd2piSdvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "ulp",
           "printedName": "ulp",
-          "declKind": "Var",
-          "usr": "s:Sd3ulpSdvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40810,10 +42421,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd3ulpSdvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40821,22 +42428,23 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd3ulpSdvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd3ulpSdvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "leastNormalMagnitude",
           "printedName": "leastNormalMagnitude",
-          "declKind": "Var",
-          "usr": "s:Sd20leastNormalMagnitudeSdvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40848,11 +42456,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd20leastNormalMagnitudeSdvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40860,22 +42463,25 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd20leastNormalMagnitudeSdvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd20leastNormalMagnitudeSdvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "leastNonzeroMagnitude",
           "printedName": "leastNonzeroMagnitude",
-          "declKind": "Var",
-          "usr": "s:Sd21leastNonzeroMagnitudeSdvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40887,11 +42493,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd21leastNonzeroMagnitudeSdvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40899,22 +42500,25 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd21leastNonzeroMagnitudeSdvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd21leastNonzeroMagnitudeSdvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "ulpOfOne",
           "printedName": "ulpOfOne",
-          "declKind": "Var",
-          "usr": "s:Sd8ulpOfOneSdvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40926,11 +42530,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd8ulpOfOneSdvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40938,21 +42537,25 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd8ulpOfOneSdvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd8ulpOfOneSdvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "exponent",
           "printedName": "exponent",
-          "declKind": "Var",
-          "usr": "s:Sd8exponentSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -40964,10 +42567,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd8exponentSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -40975,21 +42574,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd8exponentSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd8exponentSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "significand",
           "printedName": "significand",
-          "declKind": "Var",
-          "usr": "s:Sd11significandSdvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41001,10 +42602,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd11significandSdvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41012,21 +42609,23 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd11significandSdvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd11significandSdvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(sign:exponent:significand:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd4sign8exponent11significandSds17FloatingPointSignO_SiSdtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41052,19 +42651,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd4sign8exponent11significandSds17FloatingPointSignO_SiSdtcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(nan:signaling:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd3nan9signalingSds6UInt64V_Sbtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41091,19 +42689,18 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd3nan9signalingSds6UInt64V_Sbtcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "nextUp",
           "printedName": "nextUp",
-          "declKind": "Var",
-          "usr": "s:Sd6nextUpSdvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41115,10 +42712,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd6nextUpSdvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41126,22 +42719,23 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd6nextUpSdvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd6nextUpSdvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "round",
           "printedName": "round(_:)",
-          "declKind": "Func",
-          "usr": "s:Sd5roundyys25FloatingPointRoundingRuleOF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41154,40 +42748,162 @@
               "printedName": "FloatingPointRoundingRule",
               "usr": "s:s25FloatingPointRoundingRuleO"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd5roundyys25FloatingPointRoundingRuleOF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "negate",
           "printedName": "negate()",
-          "declKind": "Func",
-          "usr": "s:Sd6negateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd6negateyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd2peoiyySdz_SdtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd2seoiyySdz_SdtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd2meoiyySdz_SdtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd2deoiyySdz_SdtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "formRemainder",
           "printedName": "formRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:Sd13formRemainder10dividingByySd_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41200,20 +42916,19 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd13formRemainder10dividingByySd_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "formTruncatingRemainder",
           "printedName": "formTruncatingRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:Sd23formTruncatingRemainder10dividingByySd_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41226,40 +42941,38 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd23formTruncatingRemainder10dividingByySd_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "formSquareRoot",
           "printedName": "formSquareRoot()",
-          "declKind": "Func",
-          "usr": "s:Sd14formSquareRootyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd14formSquareRootyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "addProduct",
           "printedName": "addProduct(_:_:)",
-          "declKind": "Func",
-          "usr": "s:Sd10addProductyySd_SdtF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41278,19 +42991,19 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd10addProductyySd_SdtF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "isEqual",
           "printedName": "isEqual(to:)",
-          "declKind": "Func",
-          "usr": "s:Sd7isEqual2toSbSd_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41304,19 +43017,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd7isEqual2toSbSd_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "isLess",
           "printedName": "isLess(than:)",
-          "declKind": "Func",
-          "usr": "s:Sd6isLess4thanSbSd_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41330,19 +43042,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd6isLess4thanSbSd_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "isLessThanOrEqualTo",
           "printedName": "isLessThanOrEqualTo(_:)",
-          "declKind": "Func",
-          "usr": "s:Sd19isLessThanOrEqualToySbSdF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41356,19 +43067,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd19isLessThanOrEqualToySbSdF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isNormal",
           "printedName": "isNormal",
-          "declKind": "Var",
-          "usr": "s:Sd8isNormalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41380,10 +43090,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd8isNormalSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41391,21 +43097,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd8isNormalSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd8isNormalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isFinite",
           "printedName": "isFinite",
-          "declKind": "Var",
-          "usr": "s:Sd8isFiniteSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41417,10 +43125,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd8isFiniteSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41428,21 +43132,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd8isFiniteSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd8isFiniteSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isZero",
           "printedName": "isZero",
-          "declKind": "Var",
-          "usr": "s:Sd6isZeroSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41454,10 +43160,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd6isZeroSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41465,21 +43167,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd6isZeroSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd6isZeroSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isSubnormal",
           "printedName": "isSubnormal",
-          "declKind": "Var",
-          "usr": "s:Sd11isSubnormalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41491,10 +43195,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd11isSubnormalSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41502,21 +43202,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd11isSubnormalSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd11isSubnormalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isInfinite",
           "printedName": "isInfinite",
-          "declKind": "Var",
-          "usr": "s:Sd10isInfiniteSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41528,10 +43230,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd10isInfiniteSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41539,21 +43237,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd10isInfiniteSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd10isInfiniteSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isNaN",
           "printedName": "isNaN",
-          "declKind": "Var",
-          "usr": "s:Sd5isNaNSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41565,10 +43265,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd5isNaNSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41576,21 +43272,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd5isNaNSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd5isNaNSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isSignalingNaN",
           "printedName": "isSignalingNaN",
-          "declKind": "Var",
-          "usr": "s:Sd14isSignalingNaNSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41602,10 +43300,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd14isSignalingNaNSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41613,21 +43307,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd14isSignalingNaNSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd14isSignalingNaNSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "binade",
           "printedName": "binade",
-          "declKind": "Var",
-          "usr": "s:Sd6binadeSdvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41639,10 +43335,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd6binadeSdvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41650,21 +43342,23 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd6binadeSdvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd6binadeSdvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "significandWidth",
           "printedName": "significandWidth",
-          "declKind": "Var",
-          "usr": "s:Sd16significandWidthSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41676,10 +43370,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd16significandWidthSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41687,21 +43377,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd16significandWidthSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd16significandWidthSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(floatLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd12floatLiteralS2d_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41715,16 +43407,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd12floatLiteralS2d_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "FloatLiteralType",
           "printedName": "FloatLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Sd16FloatLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -41732,16 +43426,16 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sd16FloatLiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "RawExponent",
           "printedName": "RawExponent",
-          "declKind": "TypeAlias",
-          "usr": "s:Sd11RawExponenta",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -41749,19 +43443,16 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sd11RawExponenta",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(integerLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd14integerLiteralSds5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41775,16 +43466,18 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd14integerLiteralSds5Int64V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "IntegerLiteralType",
           "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Sd18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -41792,19 +43485,16 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sd18IntegerLiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:Sd4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41817,16 +43507,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Sd9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -41838,10 +43530,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -41849,21 +43537,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:Sd9magnitudeSdvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41875,32 +43564,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
               "declKind": "Accessor",
               "usr": "s:Sd9magnitudeSdvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds5UInt8Vcfc",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd9magnitudeSdvp",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -41910,59 +43597,24 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs5UInt8V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            }
+          "declKind": "Func",
+          "usr": "s:Sd1sopyS2dFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds4Int8Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -41972,490 +43624,22 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs4Int8V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds6UInt16Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs6UInt16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds5Int16Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs5Int16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds6UInt32Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds5Int32Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs5Int32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds6UInt64Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds5Int64Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySdSucfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
           "declKind": "Constructor",
           "usr": "s:SdySdSicfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -42465,64 +43649,61 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "GenericTypeParam",
+              "printedName": "Source"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
+          "declKind": "Constructor",
+          "usr": "s:SdySdxcSzRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<Source where Source : BinaryInteger>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SdySdSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
+              "name": "Optional",
+              "printedName": "Double?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Double",
+                  "printedName": "Double",
+                  "usr": "s:Sd"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -42530,87 +43711,49 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:Sd7exactlySdSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Inline",
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Double?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Double",
-                  "printedName": "Double",
-                  "usr": "s:Sd"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SdyS2dcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Double?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -42618,7 +43761,8 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -42626,19 +43770,19 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd7exactlySdSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SdySds7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -42652,26 +43796,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SdySds7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sd7exactlySdSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Double?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -42679,7 +43820,8 @@
                   "printedName": "Double",
                   "usr": "s:Sd"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -42687,19 +43829,147 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sd7exactlySdSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd1poiyS2d_SdtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd1soiyS2d_SdtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd1moiyS2d_SdtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd1doiyS2d_SdtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(to:)",
-          "declKind": "Func",
-          "usr": "s:Sd8distance2toS2d_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -42713,19 +43983,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd8distance2toS2d_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "advanced",
           "printedName": "advanced(by:)",
-          "declKind": "Func",
-          "usr": "s:Sd8advanced2byS2d_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -42739,16 +44008,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sd8advanced2byS2d_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:Sd6Stridea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -42756,16 +44027,16 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sd6Stridea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Sd12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -42777,10 +44048,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -42788,23 +44055,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd12customMirrors0B0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd12customMirrors0B0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:Sd25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -42816,10 +44080,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sd25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -42827,21 +44087,30 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sd25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sd25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "Float80",
-      "printedName": "Float80",
+      ],
       "declKind": "Struct",
-      "usr": "s:s7Float80V",
-      "location": "",
+      "usr": "s:Sd",
       "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
+        "Encodable",
+        "Decodable",
         "LosslessStringConvertible",
         "CustomStringConvertible",
         "CustomDebugStringConvertible",
@@ -42858,23 +44127,22 @@
         "_HasCustomAnyHashableRepresentation",
         "Strideable",
         "Comparable",
-        "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "_CVarArgPassedAsDouble",
+        "_CVarArgAligned",
+        "CVarArg"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Float80",
+      "printedName": "Float80",
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VABycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -42882,26 +44150,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80VABycfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABSgxcSyRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : StringProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Float80?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -42909,26 +44174,27 @@
                   "printedName": "Float80",
                   "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80VyABSgxcSyRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<S where S : StringProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:s7Float80V11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -42940,10 +44206,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -42951,18 +44213,23 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V11descriptionSSvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s7Float80V16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -42974,10 +44241,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -42985,18 +44248,20 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V16debugDescriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "Magnitude",
           "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s7Float80V9Magnitudea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -43004,16 +44269,15 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s7Float80V9Magnitudea",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "Exponent",
           "printedName": "Exponent",
-          "declKind": "TypeAlias",
-          "usr": "s:s7Float80V8Exponenta",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -43021,16 +44285,15 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s7Float80V8Exponenta",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "RawSignificand",
           "printedName": "RawSignificand",
-          "declKind": "TypeAlias",
-          "usr": "s:s7Float80V14RawSignificanda",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -43038,20 +44301,15 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s7Float80V14RawSignificanda",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "exponentBitCount",
           "printedName": "exponentBitCount",
-          "declKind": "Var",
-          "usr": "s:s7Float80V16exponentBitCountSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43063,11 +44321,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V16exponentBitCountSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43075,22 +44328,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V16exponentBitCountSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V16exponentBitCountSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "significandBitCount",
           "printedName": "significandBitCount",
-          "declKind": "Var",
-          "usr": "s:s7Float80V19significandBitCountSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43102,11 +44358,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V19significandBitCountSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43114,21 +44365,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V19significandBitCountSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V19significandBitCountSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "sign",
           "printedName": "sign",
-          "declKind": "Var",
-          "usr": "s:s7Float80V4signs17FloatingPointSignOvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43140,10 +44395,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V4signs17FloatingPointSignOvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43151,21 +44402,23 @@
                   "printedName": "FloatingPointSign",
                   "usr": "s:s17FloatingPointSignO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V4signs17FloatingPointSignOvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V4signs17FloatingPointSignOvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "exponentBitPattern",
           "printedName": "exponentBitPattern",
-          "declKind": "Var",
-          "usr": "s:s7Float80V18exponentBitPatternSuvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43177,10 +44430,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V18exponentBitPatternSuvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43188,21 +44437,23 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V18exponentBitPatternSuvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V18exponentBitPatternSuvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "significandBitPattern",
           "printedName": "significandBitPattern",
-          "declKind": "Var",
-          "usr": "s:s7Float80V21significandBitPatterns6UInt64Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43214,10 +44465,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V21significandBitPatterns6UInt64Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43225,21 +44472,23 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V21significandBitPatterns6UInt64Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V21significandBitPatterns6UInt64Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(sign:exponentBitPattern:significandBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V4sign18exponentBitPattern011significanddE0ABs17FloatingPointSignO_Sus6UInt64Vtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43265,19 +44514,18 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80V4sign18exponentBitPattern011significanddE0ABs17FloatingPointSignO_Sus6UInt64Vtcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "isCanonical",
           "printedName": "isCanonical",
-          "declKind": "Var",
-          "usr": "s:s7Float80V11isCanonicalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43289,10 +44537,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V11isCanonicalSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43300,22 +44544,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V11isCanonicalSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V11isCanonicalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "infinity",
           "printedName": "infinity",
-          "declKind": "Var",
-          "usr": "s:s7Float80V8infinityABvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43327,11 +44572,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V8infinityABvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43339,22 +44579,25 @@
                   "printedName": "Float80",
                   "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V8infinityABvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V8infinityABvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "nan",
           "printedName": "nan",
-          "declKind": "Var",
-          "usr": "s:s7Float80V3nanABvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43366,11 +44609,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V3nanABvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43378,22 +44616,25 @@
                   "printedName": "Float80",
                   "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V3nanABvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V3nanABvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "signalingNaN",
           "printedName": "signalingNaN",
-          "declKind": "Var",
-          "usr": "s:s7Float80V12signalingNaNABvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43405,11 +44646,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V12signalingNaNABvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43417,22 +44653,25 @@
                   "printedName": "Float80",
                   "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V12signalingNaNABvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V12signalingNaNABvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "greatestFiniteMagnitude",
           "printedName": "greatestFiniteMagnitude",
-          "declKind": "Var",
-          "usr": "s:s7Float80V23greatestFiniteMagnitudeABvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43444,11 +44683,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V23greatestFiniteMagnitudeABvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43456,22 +44690,25 @@
                   "printedName": "Float80",
                   "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V23greatestFiniteMagnitudeABvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V23greatestFiniteMagnitudeABvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "pi",
           "printedName": "pi",
-          "declKind": "Var",
-          "usr": "s:s7Float80V2piABvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43483,11 +44720,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V2piABvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43495,21 +44727,25 @@
                   "printedName": "Float80",
                   "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V2piABvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V2piABvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "ulp",
           "printedName": "ulp",
-          "declKind": "Var",
-          "usr": "s:s7Float80V3ulpABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43521,10 +44757,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V3ulpABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43532,22 +44764,23 @@
                   "printedName": "Float80",
                   "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V3ulpABvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V3ulpABvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "leastNormalMagnitude",
           "printedName": "leastNormalMagnitude",
-          "declKind": "Var",
-          "usr": "s:s7Float80V20leastNormalMagnitudeABvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43559,11 +44792,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V20leastNormalMagnitudeABvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43571,22 +44799,25 @@
                   "printedName": "Float80",
                   "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V20leastNormalMagnitudeABvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V20leastNormalMagnitudeABvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "leastNonzeroMagnitude",
           "printedName": "leastNonzeroMagnitude",
-          "declKind": "Var",
-          "usr": "s:s7Float80V21leastNonzeroMagnitudeABvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43598,11 +44829,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V21leastNonzeroMagnitudeABvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43610,22 +44836,25 @@
                   "printedName": "Float80",
                   "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V21leastNonzeroMagnitudeABvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V21leastNonzeroMagnitudeABvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "ulpOfOne",
           "printedName": "ulpOfOne",
-          "declKind": "Var",
-          "usr": "s:s7Float80V8ulpOfOneABvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43637,11 +44866,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V8ulpOfOneABvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43649,21 +44873,25 @@
                   "printedName": "Float80",
                   "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V8ulpOfOneABvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V8ulpOfOneABvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "exponent",
           "printedName": "exponent",
-          "declKind": "Var",
-          "usr": "s:s7Float80V8exponentSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43675,10 +44903,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V8exponentSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43686,21 +44910,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V8exponentSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V8exponentSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "significand",
           "printedName": "significand",
-          "declKind": "Var",
-          "usr": "s:s7Float80V11significandABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43712,10 +44938,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V11significandABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43723,21 +44945,23 @@
                   "printedName": "Float80",
                   "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V11significandABvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V11significandABvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(sign:exponent:significand:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V4sign8exponent11significandABs17FloatingPointSignO_SiABtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43763,19 +44987,18 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80V4sign8exponent11significandABs17FloatingPointSignO_SiABtcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(nan:signaling:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V3nan9signalingABs6UInt64V_Sbtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43802,19 +45025,18 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80V3nan9signalingABs6UInt64V_Sbtcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "nextUp",
           "printedName": "nextUp",
-          "declKind": "Var",
-          "usr": "s:s7Float80V6nextUpABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43826,10 +45048,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V6nextUpABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -43837,22 +45055,23 @@
                   "printedName": "Float80",
                   "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V6nextUpABvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V6nextUpABvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "round",
           "printedName": "round(_:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V5roundyys25FloatingPointRoundingRuleOF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43865,40 +45084,162 @@
               "printedName": "FloatingPointRoundingRule",
               "usr": "s:s25FloatingPointRoundingRuleO"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V5roundyys25FloatingPointRoundingRuleOF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "negate",
           "printedName": "negate()",
-          "declKind": "Func",
-          "usr": "s:s7Float80V6negateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V6negateyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "formRemainder",
           "printedName": "formRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V13formRemainder10dividingByyAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43911,20 +45252,19 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V13formRemainder10dividingByyAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "formTruncatingRemainder",
           "printedName": "formTruncatingRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V23formTruncatingRemainder10dividingByyAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43937,40 +45277,38 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V23formTruncatingRemainder10dividingByyAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "formSquareRoot",
           "printedName": "formSquareRoot()",
-          "declKind": "Func",
-          "usr": "s:s7Float80V14formSquareRootyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V14formSquareRootyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "addProduct",
           "printedName": "addProduct(_:_:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V10addProductyyAB_ABtF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -43989,19 +45327,19 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V10addProductyyAB_ABtF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "isEqual",
           "printedName": "isEqual(to:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V7isEqual2toSbAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -44015,19 +45353,18 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V7isEqual2toSbAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "isLess",
           "printedName": "isLess(than:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V6isLess4thanSbAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -44041,19 +45378,18 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V6isLess4thanSbAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "isLessThanOrEqualTo",
           "printedName": "isLessThanOrEqualTo(_:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V19isLessThanOrEqualToySbABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -44067,19 +45403,18 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V19isLessThanOrEqualToySbABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isNormal",
           "printedName": "isNormal",
-          "declKind": "Var",
-          "usr": "s:s7Float80V8isNormalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -44091,10 +45426,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V8isNormalSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -44102,21 +45433,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V8isNormalSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V8isNormalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isFinite",
           "printedName": "isFinite",
-          "declKind": "Var",
-          "usr": "s:s7Float80V8isFiniteSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -44128,10 +45461,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V8isFiniteSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -44139,21 +45468,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V8isFiniteSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V8isFiniteSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isZero",
           "printedName": "isZero",
-          "declKind": "Var",
-          "usr": "s:s7Float80V6isZeroSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -44165,10 +45496,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V6isZeroSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -44176,21 +45503,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V6isZeroSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V6isZeroSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isSubnormal",
           "printedName": "isSubnormal",
-          "declKind": "Var",
-          "usr": "s:s7Float80V11isSubnormalSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -44202,10 +45531,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V11isSubnormalSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -44213,21 +45538,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V11isSubnormalSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V11isSubnormalSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isInfinite",
           "printedName": "isInfinite",
-          "declKind": "Var",
-          "usr": "s:s7Float80V10isInfiniteSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -44239,10 +45566,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V10isInfiniteSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -44250,21 +45573,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V10isInfiniteSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V10isInfiniteSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isNaN",
           "printedName": "isNaN",
-          "declKind": "Var",
-          "usr": "s:s7Float80V5isNaNSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -44276,10 +45601,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V5isNaNSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -44287,21 +45608,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V5isNaNSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V5isNaNSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isSignalingNaN",
           "printedName": "isSignalingNaN",
-          "declKind": "Var",
-          "usr": "s:s7Float80V14isSignalingNaNSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -44313,10 +45636,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V14isSignalingNaNSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -44324,21 +45643,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V14isSignalingNaNSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V14isSignalingNaNSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "binade",
           "printedName": "binade",
-          "declKind": "Var",
-          "usr": "s:s7Float80V6binadeABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -44350,10 +45671,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V6binadeABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -44361,21 +45678,23 @@
                   "printedName": "Float80",
                   "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V6binadeABvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V6binadeABvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "significandWidth",
           "printedName": "significandWidth",
-          "declKind": "Var",
-          "usr": "s:s7Float80V16significandWidthSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -44387,10 +45706,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V16significandWidthSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -44398,21 +45713,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V16significandWidthSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V16significandWidthSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(floatLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V12floatLiteralA2B_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -44426,16 +45743,18 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80V12floatLiteralA2B_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "FloatLiteralType",
           "printedName": "FloatLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s7Float80V16FloatLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -44443,16 +45762,16 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s7Float80V16FloatLiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "RawExponent",
           "printedName": "RawExponent",
-          "declKind": "TypeAlias",
-          "usr": "s:s7Float80V11RawExponenta",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -44460,19 +45779,16 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s7Float80V11RawExponenta",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(integerLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V14integerLiteralABs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -44486,16 +45802,18 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80V14integerLiteralABs5Int64V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "IntegerLiteralType",
           "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s7Float80V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -44503,19 +45821,16 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s7Float80V18IntegerLiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -44528,16 +45843,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s7Float80V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -44549,10 +45866,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -44560,21 +45873,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:s7Float80V9magnitudeABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -44586,32 +45900,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
+                }
+              ],
               "declKind": "Accessor",
               "usr": "s:s7Float80V9magnitudeABvg",
-              "location": "",
-              "moduleName": "Swift",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABs5UInt8Vcfc",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V9magnitudeABvp",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -44621,59 +45933,24 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgs5UInt8V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            }
+          "declKind": "Func",
+          "usr": "s:s7Float80V1sopyA2BFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABs4Int8Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -44683,493 +45960,22 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgs4Int8V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABs6UInt16Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgs6UInt16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABs5Int16Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgs5Int16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABs6UInt32Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABs5Int32Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgs5Int32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABs6UInt64Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABs5Int64Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyABSucfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
           "declKind": "Constructor",
           "usr": "s:s7Float80VyABSicfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -45179,65 +45985,61 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "GenericTypeParam",
+              "printedName": "Source"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable",
-            "Available"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
+          "declKind": "Constructor",
+          "usr": "s:s7Float80VyABxcSzRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<Source where Source : BinaryInteger>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s7Float80VyABSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
+              "name": "Optional",
+              "printedName": "Float80?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Float80",
+                  "printedName": "Float80",
+                  "usr": "s:s7Float80V"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -45245,87 +46047,49 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:s7Float80V7exactlyABSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Inline",
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Float80?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Float80",
-                  "printedName": "Float80",
-                  "usr": "s:s7Float80V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s7Float80VyABSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Float80",
-              "printedName": "Float80",
-              "usr": "s:s7Float80V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Float80?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -45333,7 +46097,8 @@
                   "printedName": "Float80",
                   "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -45341,19 +46106,19 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80VyA2Bcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45367,26 +46132,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80VyA2Bcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s7Float80V7exactlyABSgAB_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Float80?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -45394,7 +46156,8 @@
                   "printedName": "Float80",
                   "usr": "s:s7Float80V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -45402,19 +46165,147 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7Float80V7exactlyABSgAB_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float80",
+              "printedName": "Float80",
+              "usr": "s:s7Float80V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(to:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V8distance2toA2B_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45428,19 +46319,18 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V8distance2toA2B_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "advanced",
           "printedName": "advanced(by:)",
-          "declKind": "Func",
-          "usr": "s:s7Float80V8advanced2byA2B_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45454,16 +46344,18 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s7Float80V8advanced2byA2B_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s7Float80V6Stridea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -45471,16 +46363,16 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s7Float80V6Stridea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s7Float80V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -45492,10 +46384,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s7Float80V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -45503,33 +46391,52 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s7Float80V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s7Float80V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s7Float80V",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "LosslessStringConvertible",
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible",
+        "BinaryFloatingPoint",
+        "FloatingPoint",
+        "ExpressibleByFloatLiteral",
+        "SignedNumeric",
+        "Numeric",
+        "_ExpressibleByBuiltinIntegerLiteral",
+        "ExpressibleByIntegerLiteral",
+        "_ExpressibleByBuiltinFloatLiteral",
+        "Hashable",
+        "Equatable",
+        "_HasCustomAnyHashableRepresentation",
+        "Strideable",
+        "Comparable",
+        "CustomReflectable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Hashable",
       "printedName": "Hashable",
-      "declKind": "Protocol",
-      "usr": "s:SH",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Equatable>",
-      "conformingProtocols": [
-        "Equatable"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SH9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -45541,11 +46448,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SH9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -45553,19 +46455,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SH9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Hashable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SH9hashValueSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SH4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Hashable>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -45578,41 +46483,31 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SH4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Hashable>",
+          "protocolReq": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SH",
+      "moduleName": "Swift",
+      "genericSig": "<Self : Equatable>",
+      "conformingProtocols": [
+        "Equatable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AnyHashable",
       "printedName": "AnyHashable",
-      "declKind": "Struct",
-      "usr": "s:s11AnyHashableV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable",
-        "CustomStringConvertible",
-        "CustomDebugStringConvertible",
-        "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s11AnyHashableVyABxcSHRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<H where H : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45625,19 +46520,19 @@
               "name": "GenericTypeParam",
               "printedName": "H"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s11AnyHashableVyABxcSHRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<H where H : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "base",
           "printedName": "base",
-          "declKind": "Var",
-          "usr": "s:s11AnyHashableV4baseypvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45648,31 +46543,61 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11AnyHashableV4baseypvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ProtocolComposition",
                   "printedName": "Any"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11AnyHashableV4baseypvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s11AnyHashableV4baseypvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyHashable",
+              "printedName": "AnyHashable",
+              "usr": "s:s11AnyHashableV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyHashable",
+              "printedName": "AnyHashable",
+              "usr": "s:s11AnyHashableV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnyHashableV2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s11AnyHashableV9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45684,10 +46609,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11AnyHashableV9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -45695,21 +46616,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11AnyHashableV9hashValueSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s11AnyHashableV9hashValueSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s11AnyHashableV4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45722,19 +46645,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnyHashableV4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:s11AnyHashableV11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45746,10 +46668,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11AnyHashableV11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -45757,18 +46675,23 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11AnyHashableV11descriptionSSvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s11AnyHashableV11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s11AnyHashableV16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -45780,10 +46703,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11AnyHashableV16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -45791,21 +46710,20 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11AnyHashableV16debugDescriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s11AnyHashableV16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s11AnyHashableV12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45817,10 +46735,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11AnyHashableV12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -45828,35 +46742,43 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11AnyHashableV12customMirrors0D0Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s11AnyHashableV12customMirrors0D0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s11AnyHashableV",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable",
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible",
+        "CustomReflectable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Hasher",
       "printedName": "Hasher",
-      "declKind": "Struct",
-      "usr": "s:s6HasherV",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s6HasherVABycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Effects"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45864,22 +46786,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6HasherVABycfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Effects"
           ]
         },
         {
           "kind": "Function",
           "name": "combine",
           "printedName": "combine(_:)",
-          "declKind": "Func",
-          "usr": "s:s6HasherV7combineyyxSHRzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<H where H : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45891,20 +46809,21 @@
               "name": "GenericTypeParam",
               "printedName": "H"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s6HasherV7combineyyxSHRzlF",
+          "moduleName": "Swift",
+          "genericSig": "<H where H : Hashable>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "combine",
           "printedName": "combine(bytes:)",
-          "declKind": "Func",
-          "usr": "s:s6HasherV7combine5bytesySW_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Effects"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45917,19 +46836,19 @@
               "printedName": "UnsafeRawBufferPointer",
               "usr": "s:SW"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s6HasherV7combine5bytesySW_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Effects"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "finalize",
           "printedName": "finalize()",
-          "declKind": "Func",
-          "usr": "s:s6HasherV8finalizeSiyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Effects"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -45937,157 +46856,143 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6HasherV8finalizeSiyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Effects"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s6HasherV",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "DefaultIndices",
       "printedName": "DefaultIndices",
-      "declKind": "Struct",
-      "usr": "s:SI",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Elements where Elements : Collection>",
-      "conformingProtocols": [
-        "Collection",
-        "Sequence",
-        "BidirectionalCollection",
-        "RandomAccessCollection"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:SI5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Elements.Index"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SI5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Elements where Elements : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:SI7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Elements.Index"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SI7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Elements where Elements : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:SI7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DefaultIndices",
               "printedName": "DefaultIndices<Elements>",
-              "usr": "s:SI",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Elements"
                 }
-              ]
+              ],
+              "usr": "s:SI"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SI7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Elements where Elements : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:SI11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DefaultIndices",
               "printedName": "DefaultIndices<Elements>",
-              "usr": "s:SI",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Elements"
                 }
-              ]
+              ],
+              "usr": "s:SI"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SI11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Elements where Elements : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:SI8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "IndexingIterator",
               "printedName": "IndexingIterator<DefaultIndices<Elements>>",
-              "usr": "s:s16IndexingIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DefaultIndices",
                   "printedName": "DefaultIndices<Elements>",
-                  "usr": "s:SI",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Elements"
                     }
-                  ]
+                  ],
+                  "usr": "s:SI"
                 }
-              ]
+              ],
+              "usr": "s:s16IndexingIteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SI8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Elements where Elements : Collection>"
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:SI10startIndex0B0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -46098,32 +47003,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SI10startIndex0B0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Elements where Elements : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Elements.Index"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SI10startIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Elements where Elements : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SI10startIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:SI8endIndex0B0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -46134,77 +47037,35 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SI8endIndex0B0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Elements where Elements : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Elements.Index"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SI8endIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Elements where Elements : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SI8endIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "Function",
-          "name": "index",
-          "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:SI5index5after5IndexQzAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "DefaultIndices<Elements>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNameAlias",
-              "name": "Index",
-              "printedName": "DefaultIndices<Elements>.Index",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "τ_0_0.Index"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "formIndex",
-          "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:SI9formIndex5aftery0B0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
+              "name": "DependentMember",
+              "printedName": "Elements.Index"
             },
             {
               "kind": "TypeNameAlias",
@@ -46218,72 +47079,66 @@
                 }
               ]
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SIy5IndexQzABcip",
+          "moduleName": "Swift",
+          "genericSig": "<Elements where Elements : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "Var",
-          "name": "indices",
-          "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:SI7indicesSIyxGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DefaultIndices",
               "printedName": "DefaultIndices<Elements>",
-              "usr": "s:SI",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Elements"
                 }
-              ]
+              ],
+              "usr": "s:SI"
             },
             {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SI7indicesSIyxGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Elements where Elements : Collection>",
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<DefaultIndices<Elements>.Index>",
               "children": [
                 {
-                  "kind": "TypeNominal",
-                  "name": "DefaultIndices",
-                  "printedName": "DefaultIndices<Elements>",
-                  "usr": "s:SI",
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "DefaultIndices<Elements>.Index",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Elements"
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Index"
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SIySIyxGSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Elements where Elements : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
-          "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:SIsSKRzrlE5index6before5IndexQzAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "printedName": "index(after:)",
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -46309,20 +47164,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SI5index5after5IndexQzAD_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Elements where Elements : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
-          "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:SIsSKRzrlE9formIndex6beforey0B0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Elements where Elements : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "printedName": "formIndex(after:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -46341,24 +47195,158 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SI9formIndex5aftery0B0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Elements where Elements : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "indices",
+          "printedName": "indices",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DefaultIndices",
+              "printedName": "DefaultIndices<Elements>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Elements"
+                }
+              ],
+              "usr": "s:SI"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DefaultIndices",
+                  "printedName": "DefaultIndices<Elements>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Elements"
+                    }
+                  ],
+                  "usr": "s:SI"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SI7indicesSIyxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Elements where Elements : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SI7indicesSIyxGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "index",
+          "printedName": "index(before:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "DefaultIndices<Elements>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "DefaultIndices<Elements>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SIsSKRzrlE5index6before5IndexQzAD_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Elements where Elements : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(before:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "DefaultIndices<Elements>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SIsSKRzrlE9formIndex6beforey0B0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Elements where Elements : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:SI",
+      "moduleName": "Swift",
+      "genericSig": "<Elements where Elements : Collection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Collection",
+        "Sequence",
+        "BidirectionalCollection",
+        "RandomAccessCollection"
       ]
     },
     {
       "kind": "Function",
       "name": "readLine",
       "printedName": "readLine(strippingNewline:)",
-      "declKind": "Func",
-      "usr": "s:s8readLine16strippingNewlineSSSgSb_tF",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Optional",
           "printedName": "String?",
-          "usr": "s:Sq",
           "children": [
             {
               "kind": "TypeNominal",
@@ -46366,7 +47354,8 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "usr": "s:Sq"
         },
         {
           "kind": "TypeNominal",
@@ -46375,100 +47364,59 @@
           "hasDefaultArg": true,
           "usr": "s:Sb"
         }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "IntMax",
-      "printedName": "IntMax",
-      "declKind": "TypeAlias",
-      "usr": "s:s6IntMaxa",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Available"
       ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "Int64",
-          "printedName": "Int64",
-          "usr": "s:s5Int64V"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "UIntMax",
-      "printedName": "UIntMax",
-      "declKind": "TypeAlias",
-      "usr": "s:s7UIntMaxa",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "UInt64",
-          "printedName": "UInt64",
-          "usr": "s:s6UInt64V"
-        }
-      ]
+      "declKind": "Func",
+      "usr": "s:s8readLine16strippingNewlineSSSgSb_tF",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "Numeric",
       "printedName": "Numeric",
-      "declKind": "Protocol",
-      "usr": "s:Sj",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Equatable, Self : ExpressibleByIntegerLiteral, Self.Magnitude : Comparable, Self.Magnitude : Numeric>",
-      "conformingProtocols": [
-        "Equatable",
-        "ExpressibleByIntegerLiteral"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sj7exactlyxSgqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Numeric, T : BinaryInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sj7exactlyxSgqd___tcSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : Numeric, T : BinaryInteger>",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Magnitude",
+          "printedName": "Magnitude",
+          "declKind": "AssociatedType",
+          "usr": "s:Sj9MagnitudeQa",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:Sj9magnitude9MagnitudeQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -46479,91 +47427,196 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sj9magnitude9MagnitudeQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Numeric>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Magnitude"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sj9magnitude9MagnitudeQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Numeric>"
             }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "SignedNumeric",
-      "printedName": "SignedNumeric",
-      "declKind": "Protocol",
-      "usr": "s:s13SignedNumericP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Numeric>",
-      "conformingProtocols": [
-        "Numeric",
-        "Equatable",
-        "ExpressibleByIntegerLiteral"
-      ],
-      "children": [
-        {
-          "kind": "Function",
-          "name": "negate",
-          "printedName": "negate()",
-          "declKind": "Func",
-          "usr": "s:s13SignedNumericP6negateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SignedNumeric>",
-          "mutating": true,
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "negate",
-          "printedName": "negate()",
-          "declKind": "Func",
-          "usr": "s:s13SignedNumericPsE6negateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SignedNumeric>",
-          "mutating": true,
-          "declAttributes": [
-            "Transparent"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            }
-          ]
+          "declKind": "Var",
+          "usr": "s:Sj9magnitude9MagnitudeQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
-          "name": "abs",
-          "printedName": "abs(_:)",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
           "declKind": "Func",
-          "usr": "s:s13SignedNumericPsSLRzrlE3absyxxFZ",
-          "location": "",
+          "usr": "s:Sj1poiyxx_xtFZ",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Comparable, Self : SignedNumeric>",
+          "genericSig": "<Self where Self : Numeric>",
           "static": true,
-          "declAttributes": [
-            "Transparent",
-            "Available"
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
           ],
+          "declKind": "Func",
+          "usr": "s:Sj2peoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Numeric>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sj1soiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Numeric>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sj2seoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Numeric>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sj1moiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Numeric>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sj2meoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Numeric>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -46575,22 +47628,137 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SjsE1popyxxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Numeric>",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:Sj",
+      "moduleName": "Swift",
+      "genericSig": "<Self : Equatable, Self : ExpressibleByIntegerLiteral, Self.Magnitude : Comparable, Self.Magnitude : Numeric>",
+      "conformingProtocols": [
+        "Equatable",
+        "ExpressibleByIntegerLiteral"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "SignedNumeric",
+      "printedName": "SignedNumeric",
+      "children": [
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13SignedNumericP1sopyxxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SignedNumeric>",
+          "static": true,
+          "protocolReq": true,
+          "declAttributes": [
+            "Prefix"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "negate",
+          "printedName": "negate()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13SignedNumericP6negateyyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SignedNumeric>",
+          "protocolReq": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13SignedNumericPsE1sopyxxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SignedNumeric>",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "negate",
+          "printedName": "negate()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13SignedNumericPsE6negateyyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SignedNumeric>",
+          "declAttributes": [
+            "Transparent"
+          ],
+          "mutating": true
+        }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s13SignedNumericP",
+      "moduleName": "Swift",
+      "genericSig": "<Self : Numeric>",
+      "conformingProtocols": [
+        "Numeric",
+        "Equatable",
+        "ExpressibleByIntegerLiteral"
       ]
     },
     {
       "kind": "Function",
       "name": "abs",
       "printedName": "abs(_:)",
-      "declKind": "Func",
-      "usr": "s:s3absyxxs13SignedNumericRz9MagnitudeSjQzRszlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : SignedNumeric, T == T.Magnitude>",
-      "declAttributes": [
-        "Transparent"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -46602,61 +47770,48 @@
           "name": "GenericTypeParam",
           "printedName": "T"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s3absyxxs13SignedNumericRz9MagnitudeSjQzRszlF",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : SignedNumeric, T == T.Magnitude>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "abs",
       "printedName": "abs(_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "T"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "T"
+        }
+      ],
       "declKind": "Func",
       "usr": "s:s3absyxxSLRzs13SignedNumericRzlF",
-      "location": "",
       "moduleName": "Swift",
       "genericSig": "<T where T : Comparable, T : SignedNumeric>",
       "declAttributes": [
         "Inlinable"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        }
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "BinaryInteger",
       "printedName": "BinaryInteger",
-      "declKind": "Protocol",
-      "usr": "s:Sz",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : CustomStringConvertible, Self : Hashable, Self : Numeric, Self : Strideable, Self.Magnitude : BinaryInteger, Self.Magnitude == Self.Magnitude.Magnitude, Self.Words : Sequence, Self.Words.Element == UInt>",
-      "conformingProtocols": [
-        "Hashable",
-        "Numeric",
-        "CustomStringConvertible",
-        "Strideable",
-        "Equatable",
-        "ExpressibleByIntegerLiteral",
-        "Comparable"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "isSigned",
           "printedName": "isSigned",
-          "declKind": "Var",
-          "usr": "s:Sz8isSignedSbvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -46668,12 +47823,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sz8isSignedSbvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryInteger>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -46681,71 +47830,54 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sz8isSignedSbvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : BinaryInteger>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sz8isSignedSbvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Sz7exactlyxSgqd___tcSBRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : BinaryInteger, T : BinaryFloatingPoint>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
+          ],
           "declKind": "Constructor",
-          "usr": "s:Szyxqd__cSBRd__lufc",
-          "location": "",
+          "usr": "s:Sz7exactlyxSgqd___tcSBRd__lufc",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : BinaryInteger, T : BinaryFloatingPoint>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:Szyxqd__cSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : BinaryInteger, T : BinaryInteger>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -46757,17 +47889,39 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Szyxqd__cSBRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : BinaryInteger, T : BinaryFloatingPoint>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "T"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Szyxqd__cSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : BinaryInteger, T : BinaryInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(truncatingIfNeeded:)",
-          "declKind": "Constructor",
-          "usr": "s:Sz18truncatingIfNeededxqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : BinaryInteger, T : BinaryInteger>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -46779,17 +47933,17 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sz18truncatingIfNeededxqd___tcSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : BinaryInteger, T : BinaryInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(clamping:)",
-          "declKind": "Constructor",
-          "usr": "s:Sz8clampingxqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : BinaryInteger, T : BinaryInteger>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -46801,16 +47955,26 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sz8clampingxqd___tcSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : BinaryInteger, T : BinaryInteger>",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Words",
+          "printedName": "Words",
+          "declKind": "AssociatedType",
+          "usr": "s:Sz5WordsQa",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:Sz5words5WordsQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -46821,29 +47985,28 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sz5words5WordsQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Words"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sz5words5WordsQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : BinaryInteger>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sz5words5WordsQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:Sz8bitWidthSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -46855,11 +48018,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sz8bitWidthSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -46867,18 +48025,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sz8bitWidthSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : BinaryInteger>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sz8bitWidthSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:Sz20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -46890,11 +48052,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sz20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -46902,19 +48059,632 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sz20trailingZeroBitCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : BinaryInteger>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sz20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1doiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2deoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1roiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2reoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1poiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2peoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1soiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2seoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1moiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2meoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "~",
+          "printedName": "~(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1topyxxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "protocolReq": true,
+          "declAttributes": [
+            "Prefix"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1aoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2aeoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1ooiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2oeoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz1xoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2xeoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": ">>",
+          "printedName": ">>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "RHS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2ggoiyxx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, RHS where Self : BinaryInteger, RHS : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": ">>=",
+          "printedName": ">>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "RHS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz3ggeoiyyxz_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, RHS where Self : BinaryInteger, RHS : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "<<",
+          "printedName": "<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "RHS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz2lloiyxx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, RHS where Self : BinaryInteger, RHS : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "<<=",
+          "printedName": "<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "RHS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz3lleoiyyxz_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, RHS where Self : BinaryInteger, RHS : BinaryInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
           "name": "quotientAndRemainder",
           "printedName": "quotientAndRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:Sz20quotientAndRemainder10dividingByx0A0_x9remaindertx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryInteger>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -46938,77 +48708,95 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz20quotientAndRemainder10dividingByx0A0_x9remaindertx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "isMultiple",
+          "printedName": "isMultiple(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz10isMultiple2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:Sz6signumxyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DynamicSelf",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sz6signumxyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:SzsExycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryInteger>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SzsExycfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:SzsE6signumxyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryInteger>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE6signumxyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "quotientAndRemainder",
           "printedName": "quotientAndRemainder(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:SzsE20quotientAndRemainder10dividingByx0A0_x9remaindertx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -47032,19 +48820,196 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE20quotientAndRemainder10dividingByx0A0_x9remaindertx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isMultiple",
+          "printedName": "isMultiple(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE10isMultiple2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE1aoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE1ooiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE1xoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">>",
+          "printedName": ">>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "RHS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2ggoiyxx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, RHS where Self : BinaryInteger, RHS : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<<",
+          "printedName": "<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "RHS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2lloiyxx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, RHS where Self : BinaryInteger, RHS : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
           ]
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:SzsE11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -47056,11 +49021,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SzsE11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : BinaryInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -47068,23 +49028,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SzsE11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : BinaryInteger>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SzsE11descriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(to:)",
-          "declKind": "Func",
-          "usr": "s:SzsE8distance2toSix_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryInteger>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -47097,21 +49055,20 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE8distance2toSix_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "advanced",
           "printedName": "advanced(by:)",
-          "declKind": "Func",
-          "usr": "s:SzsE8advanced2byxSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryInteger>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -47124,43 +49081,332 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE8advanced2byxSi_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
-          "name": "toIntMax",
-          "printedName": "toIntMax()",
-          "declKind": "Func",
-          "usr": "s:SzsE8toIntMaxs5Int64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BinaryInteger>",
-          "declAttributes": [
-            "Available"
-          ],
+          "name": "==",
+          "printedName": "==(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2eeoiySbx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : BinaryInteger, Other : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "!=",
+          "printedName": "!=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2neoiySbx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : BinaryInteger, Other : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE1loiySbx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : BinaryInteger, Other : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2leoiySbx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : BinaryInteger, Other : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2geoiySbx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : BinaryInteger, Other : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE1goiySbx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : BinaryInteger, Other : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "!=",
+          "printedName": "!=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2neoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2leoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE2geoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SzsE1goiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "FixedWidthInteger",
-      "printedName": "FixedWidthInteger",
+      ],
       "declKind": "Protocol",
-      "usr": "s:s17FixedWidthIntegerP",
-      "location": "",
+      "usr": "s:Sz",
       "moduleName": "Swift",
-      "genericSig": "<Self : BinaryInteger, Self : LosslessStringConvertible, Self.Magnitude : FixedWidthInteger, Self.Magnitude : UnsignedInteger, Self.Stride : FixedWidthInteger, Self.Stride : SignedInteger>",
+      "genericSig": "<Self : CustomStringConvertible, Self : Hashable, Self : Numeric, Self : Strideable, Self.Magnitude : BinaryInteger, Self.Magnitude == Self.Magnitude.Magnitude, Self.Words : RandomAccessCollection, Self.Words.Element == UInt, Self.Words.Index == Int>",
       "conformingProtocols": [
-        "BinaryInteger",
-        "LosslessStringConvertible",
         "Hashable",
         "Numeric",
         "CustomStringConvertible",
@@ -47168,17 +49414,17 @@
         "Equatable",
         "ExpressibleByIntegerLiteral",
         "Comparable"
-      ],
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "FixedWidthInteger",
+      "printedName": "FixedWidthInteger",
       "children": [
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerP03bitB0SivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -47190,12 +49436,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerP03bitB0SivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -47203,19 +49443,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerP03bitB0SivgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FixedWidthInteger>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerP03bitB0SivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "max",
           "printedName": "max",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerP3maxxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -47226,31 +49471,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerP3maxxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerP3maxxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FixedWidthInteger>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerP3maxxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "min",
           "printedName": "min",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerP3minxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -47261,31 +49505,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerP3minxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerP3minxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FixedWidthInteger>",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerP3minxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerP23addingReportingOverflowyx12partialValue_Sb8overflowtxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -47310,17 +49553,17 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP23addingReportingOverflowyx12partialValue_Sb8overflowtxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerP28subtractingReportingOverflowyx12partialValue_Sb8overflowtxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -47345,17 +49588,17 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP28subtractingReportingOverflowyx12partialValue_Sb8overflowtxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerP27multipliedReportingOverflow2byx12partialValue_Sb8overflowtx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -47380,17 +49623,17 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP27multipliedReportingOverflow2byx12partialValue_Sb8overflowtx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerP24dividedReportingOverflow2byx12partialValue_Sb8overflowtx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -47415,17 +49658,17 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP24dividedReportingOverflow2byx12partialValue_Sb8overflowtx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerP26remainderReportingOverflow10dividingByx12partialValue_Sb8overflowtx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -47450,17 +49693,17 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP26remainderReportingOverflow10dividingByx12partialValue_Sb8overflowtx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerP014multipliedFullB02byx4high_9MagnitudeQz3lowtx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -47484,17 +49727,17 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP014multipliedFullB02byx4high_9MagnitudeQz3lowtx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerP012dividingFullB0yx8quotient_x9remaindertx4high_9MagnitudeQz3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -47530,16 +49773,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP012dividingFullB0yx8quotient_x9remaindertx4high_9MagnitudeQz3lowt_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerP15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -47551,11 +49795,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerP15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -47563,18 +49802,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerP15nonzeroBitCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FixedWidthInteger>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerP15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerP19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -47586,11 +49829,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerP19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -47598,19 +49836,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerP19leadingZeroBitCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FixedWidthInteger>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerP19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bigEndian:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerP9bigEndianxx_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -47622,17 +49863,17 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerP9bigEndianxx_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(littleEndian:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerP12littleEndianxx_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -47644,16 +49885,17 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerP12littleEndianxx_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "bigEndian",
           "printedName": "bigEndian",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerP9bigEndianxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -47664,29 +49906,28 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerP9bigEndianxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerP9bigEndianxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FixedWidthInteger>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerP9bigEndianxvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "littleEndian",
           "printedName": "littleEndian",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerP12littleEndianxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -47697,29 +49938,28 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerP12littleEndianxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerP12littleEndianxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FixedWidthInteger>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerP12littleEndianxvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerP11byteSwappedxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -47730,47 +49970,153 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerP11byteSwappedxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerP11byteSwappedxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FixedWidthInteger>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerP11byteSwappedxvp",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP3aggoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP4aggeoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DynamicSelf",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP3alloiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "static": true,
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerP4alleoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "static": true,
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:radix:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerPsE_5radixxSgqd___SitcSyRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, S where Self : FixedWidthInteger, S : StringProtocol>",
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -47784,35 +50130,33 @@
               "hasDefaultArg": true,
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerPsE_5radixxSgqd___SitcSyRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, S where Self : FixedWidthInteger, S : StringProtocol>",
+          "declAttributes": [
+            "Semantics",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerPsEyxSgSScfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "declAttributes": [
-            "Inline",
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -47820,19 +50164,21 @@
               "printedName": "String",
               "usr": "s:SS"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerPsEyxSgSScfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "declAttributes": [
+            "Inline",
+            "Semantics",
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerPsE03bitB0Sivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -47844,11 +50190,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerPsE03bitB0Sivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -47856,22 +50197,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerPsE03bitB0Sivg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FixedWidthInteger>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerPsE03bitB0Sivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(littleEndian:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerPsE12littleEndianxx_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -47883,20 +50226,19 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerPsE12littleEndianxx_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bigEndian:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerPsE9bigEndianxx_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -47908,19 +50250,19 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerPsE9bigEndianxx_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "littleEndian",
           "printedName": "littleEndian",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerPsE12littleEndianxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -47931,32 +50273,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerPsE12littleEndianxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17FixedWidthIntegerPsE12littleEndianxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FixedWidthInteger>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerPsE12littleEndianxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "bigEndian",
           "printedName": "bigEndian",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerPsE9bigEndianxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -47967,73 +50307,254 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
               "declKind": "Accessor",
               "usr": "s:s17FixedWidthIntegerPsE9bigEndianxvg",
-              "location": "",
               "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
+              "genericSig": "<Self where Self : FixedWidthInteger>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17FixedWidthIntegerPsE9bigEndianxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3aggoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3aggoiyxx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : FixedWidthInteger, Other : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE4aggeoiyyxz_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : FixedWidthInteger, Other : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3alloiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3alloiyxx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : FixedWidthInteger, Other : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE4alleoiyyxz_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : FixedWidthInteger, Other : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
           ]
         },
         {
           "kind": "Function",
           "name": "random",
           "printedName": "random(in:using:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Self>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "T"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:s17FixedWidthIntegerPsE6random2in5usingxSnyxG_qd__ztSGRd__lFZ",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : FixedWidthInteger, T : RandomNumberGenerator>",
           "static": true,
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Self>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
           ]
         },
         {
           "kind": "Function",
           "name": "random",
           "printedName": "random(in:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE6random2inxSnyxG_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -48044,30 +50565,29 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Self>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE6random2inxSnyxG_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "random",
           "printedName": "random(in:using:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE6random2in5usingxSNyxG_qd__ztSGRd__lFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : FixedWidthInteger, T : RandomNumberGenerator>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -48078,35 +50598,34 @@
               "kind": "TypeNominal",
               "name": "ClosedRange",
               "printedName": "ClosedRange<Self>",
-              "usr": "s:SN",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:SN"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE6random2in5usingxSNyxG_qd__ztSGRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : FixedWidthInteger, T : RandomNumberGenerator>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "random",
           "printedName": "random(in:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE6random2inxSNyxG_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -48117,31 +50636,179 @@
               "kind": "TypeNominal",
               "name": "ClosedRange",
               "printedName": "ClosedRange<Self>",
-              "usr": "s:SN",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:SN"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE6random2inxSNyxG_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "~",
+          "printedName": "~(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE1topyxxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Prefix",
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">>",
+          "printedName": ">>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE2ggoiyxx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : FixedWidthInteger, Other : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">>=",
+          "printedName": ">>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3ggeoiyyxz_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : FixedWidthInteger, Other : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Semantics",
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<<",
+          "printedName": "<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE2lloiyxx_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : FixedWidthInteger, Other : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<<=",
+          "printedName": "<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3lleoiyyxz_qd__tSzRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : FixedWidthInteger, Other : BinaryInteger>",
+          "static": true,
+          "declAttributes": [
+            "Semantics",
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerPsEyxqd__cSBRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : FixedWidthInteger, T : BinaryFloatingPoint>",
-          "declAttributes": [
-            "Inline",
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -48153,56 +50820,54 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerPsE7exactlyxSgqd___tcSBRd__lufc",
-          "location": "",
+          "usr": "s:s17FixedWidthIntegerPsEyxqd__cSBRd__lufc",
           "moduleName": "Swift",
           "genericSig": "<Self, T where Self : FixedWidthInteger, T : BinaryFloatingPoint>",
           "declAttributes": [
             "Inline",
             "Semantics",
             "Inlinable"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerPsE7exactlyxSgqd___tcSBRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : FixedWidthInteger, T : BinaryFloatingPoint>",
+          "declAttributes": [
+            "Inlinable",
+            "Semantics"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(clamping:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerPsE8clampingxqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Other where Self : FixedWidthInteger, Other : BinaryInteger>",
-          "declAttributes": [
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -48214,121 +50879,20 @@
               "name": "GenericTypeParam",
               "printedName": "Other"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "unsafeAdding",
-          "printedName": "unsafeAdding(_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE12unsafeAddingyxxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "declAttributes": [
-            "Transparent"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "unsafeSubtracting",
-          "printedName": "unsafeSubtracting(_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE17unsafeSubtractingyxxF",
-          "location": "",
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerPsE8clampingxqd___tcSzRd__lufc",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "genericSig": "<Self, Other where Self : FixedWidthInteger, Other : BinaryInteger>",
           "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "unsafeMultiplied",
-          "printedName": "unsafeMultiplied(by:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE16unsafeMultiplied2byxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "unsafeDivided",
-          "printedName": "unsafeDivided(by:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE13unsafeDivided2byxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
+            "Semantics",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(truncatingIfNeeded:)",
-          "declKind": "Constructor",
-          "usr": "s:s17FixedWidthIntegerPsE18truncatingIfNeededxqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : FixedWidthInteger, T : BinaryInteger>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -48340,41 +50904,24 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s17FixedWidthIntegerPsE18truncatingIfNeededxqd___tcSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : FixedWidthInteger, T : BinaryInteger>",
+          "declAttributes": [
+            "Inline"
           ]
         },
         {
           "kind": "Function",
-          "name": "addWithOverflow",
-          "printedName": "addWithOverflow(_:_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE15addWithOverflowyx_Sb8overflowtx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "name": "&+",
+          "printedName": "&+(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(Self, overflow: Bool)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
+              "name": "GenericTypeParam",
+              "printedName": "Self"
             },
             {
               "kind": "TypeNominal",
@@ -48386,41 +50933,25 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE2apoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
-          "name": "subtractWithOverflow",
-          "printedName": "subtractWithOverflow(_:_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE20subtractWithOverflowyx_Sb8overflowtx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "name": "&+=",
+          "printedName": "&+=(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(Self, overflow: Bool)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
+              "name": "Void",
+              "printedName": "()"
             },
             {
               "kind": "TypeNominal",
@@ -48432,41 +50963,25 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3apeoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
-          "name": "multiplyWithOverflow",
-          "printedName": "multiplyWithOverflow(_:_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE20multiplyWithOverflowyx_Sb8overflowtx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "name": "&-",
+          "printedName": "&-(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(Self, overflow: Bool)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
+              "name": "GenericTypeParam",
+              "printedName": "Self"
             },
             {
               "kind": "TypeNominal",
@@ -48478,41 +50993,25 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE2asoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
-          "name": "divideWithOverflow",
-          "printedName": "divideWithOverflow(_:_:)",
-          "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE18divideWithOverflowyx_Sb8overflowtx_xtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : FixedWidthInteger>",
-          "static": true,
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "name": "&-=",
+          "printedName": "&-=(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(Self, overflow: Bool)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
+              "name": "Void",
+              "printedName": "()"
             },
             {
               "kind": "TypeNominal",
@@ -48524,106 +51023,84 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3aseoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
-          "name": "remainderWithOverflow",
-          "printedName": "remainderWithOverflow(_:_:)",
+          "name": "&*",
+          "printedName": "&*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
           "declKind": "Func",
-          "usr": "s:s17FixedWidthIntegerPsE21remainderWithOverflowyx_Sb8overflowtx_xtFZ",
-          "location": "",
+          "usr": "s:s17FixedWidthIntegerPsE2amoiyxx_xtFZ",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : FixedWidthInteger>",
           "static": true,
           "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(Self, overflow: Bool)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            }
+            "Transparent"
           ]
         },
         {
-          "kind": "Var",
-          "name": "allZeros",
-          "printedName": "allZeros",
-          "declKind": "Var",
-          "usr": "s:s17FixedWidthIntegerPsE8allZerosxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
+          "kind": "Function",
+          "name": "&*=",
+          "printedName": "&*=(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Self"
             },
             {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17FixedWidthIntegerPsE8allZerosxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17FixedWidthIntegerPsE3ameoiyyxz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "UnsignedInteger",
-      "printedName": "UnsignedInteger",
+      ],
       "declKind": "Protocol",
-      "usr": "s:SU",
-      "location": "",
+      "usr": "s:s17FixedWidthIntegerP",
       "moduleName": "Swift",
-      "genericSig": "<Self : BinaryInteger>",
+      "genericSig": "<Self : BinaryInteger, Self : LosslessStringConvertible, Self.Magnitude : FixedWidthInteger, Self.Magnitude : UnsignedInteger, Self.Stride : FixedWidthInteger, Self.Stride : SignedInteger>",
       "conformingProtocols": [
         "BinaryInteger",
+        "LosslessStringConvertible",
         "Hashable",
         "Numeric",
         "CustomStringConvertible",
@@ -48631,19 +51108,17 @@
         "Equatable",
         "ExpressibleByIntegerLiteral",
         "Comparable"
-      ],
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "UnsignedInteger",
+      "printedName": "UnsignedInteger",
       "children": [
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:SUsE9magnitudexvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -48654,33 +51129,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SUsE9magnitudexvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : UnsignedInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SUsE9magnitudexvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : UnsignedInteger>",
+              "declAttributes": [
+                "Inline"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SUsE9magnitudexvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "isSigned",
           "printedName": "isSigned",
-          "declKind": "Var",
-          "usr": "s:SUsE8isSignedSbvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -48692,12 +51164,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SUsE8isSignedSbvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : UnsignedInteger>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -48705,24 +51171,26 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SUsE8isSignedSbvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : UnsignedInteger>",
+              "static": true,
+              "declAttributes": [
+                "Inline"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SUsE8isSignedSbvpZ",
+          "moduleName": "Swift",
+          "static": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SUss17FixedWidthIntegerRzrlEyxqd__cSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : FixedWidthInteger, Self : UnsignedInteger, T : BinaryInteger>",
-          "declAttributes": [
-            "Inline",
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -48734,55 +51202,53 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SUss17FixedWidthIntegerRzrlEyxqd__cSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : FixedWidthInteger, Self : UnsignedInteger, T : BinaryInteger>",
+          "declAttributes": [
+            "Inline",
+            "Semantics"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:SUss17FixedWidthIntegerRzrlE7exactlyxSgqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : FixedWidthInteger, Self : UnsignedInteger, T : BinaryInteger>",
-          "declAttributes": [
-            "Inline",
-            "Semantics",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SUss17FixedWidthIntegerRzrlE7exactlyxSgqd___tcSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : FixedWidthInteger, Self : UnsignedInteger, T : BinaryInteger>",
+          "declAttributes": [
+            "Inline",
+            "Semantics"
           ]
         },
         {
           "kind": "Var",
           "name": "max",
           "printedName": "max",
-          "declKind": "Var",
-          "usr": "s:SUss17FixedWidthIntegerRzrlE3maxxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -48793,34 +51259,32 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SUss17FixedWidthIntegerRzrlE3maxxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger, Self : UnsignedInteger>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SUss17FixedWidthIntegerRzrlE3maxxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FixedWidthInteger, Self : UnsignedInteger>",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SUss17FixedWidthIntegerRzrlE3maxxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "min",
           "printedName": "min",
-          "declKind": "Var",
-          "usr": "s:SUss17FixedWidthIntegerRzrlE3minxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -48831,52 +51295,305 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SUss17FixedWidthIntegerRzrlE3minxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger, Self : UnsignedInteger>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SUss17FixedWidthIntegerRzrlE3minxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FixedWidthInteger, Self : UnsignedInteger>",
+              "static": true
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "toUIntMax",
-          "printedName": "toUIntMax()",
-          "declKind": "Func",
-          "usr": "s:SUsE9toUIntMaxs6UInt64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnsignedInteger>",
-          "declAttributes": [
-            "Available"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
+          "declKind": "Var",
+          "usr": "s:SUss17FixedWidthIntegerRzrlE3minxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SU",
+      "moduleName": "Swift",
+      "genericSig": "<Self : BinaryInteger>",
+      "conformingProtocols": [
+        "BinaryInteger",
+        "Hashable",
+        "Numeric",
+        "CustomStringConvertible",
+        "Strideable",
+        "Equatable",
+        "ExpressibleByIntegerLiteral",
+        "Comparable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "SignedInteger",
       "printedName": "SignedInteger",
+      "children": [
+        {
+          "kind": "Var",
+          "name": "isSigned",
+          "printedName": "isSigned",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SZsE8isSignedSbvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : SignedInteger>",
+              "static": true,
+              "declAttributes": [
+                "Inline"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SZsE8isSignedSbvpZ",
+          "moduleName": "Swift",
+          "static": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "T"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SZss17FixedWidthIntegerRzrlEyxqd__cSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : FixedWidthInteger, Self : SignedInteger, T : BinaryInteger>",
+          "declAttributes": [
+            "Inline",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Self?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "T"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SZss17FixedWidthIntegerRzrlE7exactlyxSgqd___tcSzRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : FixedWidthInteger, Self : SignedInteger, T : BinaryInteger>",
+          "declAttributes": [
+            "Inline",
+            "Semantics"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "max",
+          "printedName": "max",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SZss17FixedWidthIntegerRzrlE3maxxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FixedWidthInteger, Self : SignedInteger>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SZss17FixedWidthIntegerRzrlE3maxxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "min",
+          "printedName": "min",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SZss17FixedWidthIntegerRzrlE3minxvgZ",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : FixedWidthInteger, Self : SignedInteger>",
+              "static": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SZss17FixedWidthIntegerRzrlE3minxvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "isMultiple",
+          "printedName": "isMultiple(of:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SZss17FixedWidthIntegerRzrlE10isMultiple2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger, Self : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&+",
+          "printedName": "&+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SZss17FixedWidthIntegerRzrlE2apoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger, Self : SignedInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&-",
+          "printedName": "&-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SZss17FixedWidthIntegerRzrlE2asoiyxx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : FixedWidthInteger, Self : SignedInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        }
+      ],
       "declKind": "Protocol",
       "usr": "s:SZ",
-      "location": "",
       "moduleName": "Swift",
       "genericSig": "<Self : BinaryInteger, Self : SignedNumeric>",
       "conformingProtocols": [
@@ -48889,229 +51606,41 @@
         "Equatable",
         "ExpressibleByIntegerLiteral",
         "Comparable"
-      ],
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "numericCast",
+      "printedName": "numericCast(_:)",
       "children": [
         {
-          "kind": "Var",
-          "name": "isSigned",
-          "printedName": "isSigned",
-          "declKind": "Var",
-          "usr": "s:SZsE8isSignedSbvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Bool",
-              "printedName": "Bool",
-              "usr": "s:Sb"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SZsE8isSignedSbvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : SignedInteger>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                }
-              ]
-            }
-          ]
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "U"
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SZss17FixedWidthIntegerRzrlEyxqd__cSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : FixedWidthInteger, Self : SignedInteger, T : BinaryInteger>",
-          "declAttributes": [
-            "Inline",
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:SZss17FixedWidthIntegerRzrlE7exactlyxSgqd___tcSzRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : FixedWidthInteger, Self : SignedInteger, T : BinaryInteger>",
-          "declAttributes": [
-            "Inline",
-            "Semantics",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Self?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "max",
-          "printedName": "max",
-          "declKind": "Var",
-          "usr": "s:SZss17FixedWidthIntegerRzrlE3maxxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SZss17FixedWidthIntegerRzrlE3maxxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger, Self : SignedInteger>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "min",
-          "printedName": "min",
-          "declKind": "Var",
-          "usr": "s:SZss17FixedWidthIntegerRzrlE3minxvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SZss17FixedWidthIntegerRzrlE3minxvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : FixedWidthInteger, Self : SignedInteger>",
-              "static": true,
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Self"
-                }
-              ]
-            }
-          ]
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "T"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s11numericCastyq_xSzRzSzR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<T, U where T : BinaryInteger, U : BinaryInteger>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UInt8",
       "printedName": "UInt8",
-      "declKind": "Struct",
-      "usr": "s:s5UInt8V",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Comparable",
-        "UnsignedInteger",
-        "_ExpressibleByBuiltinIntegerLiteral",
-        "BinaryInteger",
-        "LosslessStringConvertible",
-        "Numeric",
-        "CustomStringConvertible",
-        "Strideable",
-        "ExpressibleByIntegerLiteral",
-        "FixedWidthInteger",
-        "Decodable",
-        "Encodable",
-        "Hashable",
-        "Equatable",
-        "_HasCustomAnyHashableRepresentation",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "_StringElement",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "IntegerLiteralType",
           "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s5UInt8V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -49119,19 +51648,15 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5UInt8V18IntegerLiteralTypea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V10bitPatternABs4Int8V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49145,25 +51670,57 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5UInt8V10bitPatternABs4Int8V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s5UInt8VyABSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
+              "name": "Optional",
+              "printedName": "UInt8?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt8",
+                  "printedName": "UInt8",
+                  "usr": "s:s5UInt8V"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -49171,85 +51728,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:s5UInt8V7exactlyABSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UInt8?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt8",
-                  "printedName": "UInt8",
-                  "usr": "s:s5UInt8V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s5UInt8VyABSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt8",
-              "printedName": "UInt8",
-              "usr": "s:s5UInt8V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49257,7 +51777,8 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -49265,19 +51786,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5UInt8V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8VyABs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49291,25 +51811,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5UInt8VyABs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V7exactlyABSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49317,7 +51835,8 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -49325,19 +51844,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5UInt8V7exactlyABSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49364,19 +52070,18 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49403,19 +52108,18 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49442,19 +52146,18 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49481,19 +52184,18 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49520,20 +52222,204 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2reoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2aeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2oeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2xeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V4aggeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V4alleoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49545,11 +52431,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49557,21 +52438,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49583,10 +52468,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49594,21 +52475,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49620,10 +52503,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49631,21 +52510,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -49657,10 +52538,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49668,41 +52545,33 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:s5UInt8V5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Indices",
               "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:s5UInt8V5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<Int>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -49710,24 +52579,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5UInt8V5WordsV7Indicesa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s5UInt8V5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Slice",
                   "printedName": "Slice<UInt8.Words>",
-                  "usr": "s:s5SliceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -49735,21 +52603,18 @@
                       "printedName": "UInt8.Words",
                       "usr": "s:s5UInt8V5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s5SliceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5UInt8V5WordsV11SubSequencea",
+              "moduleName": "Swift"
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s5UInt8V5WordsVyAdBcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49763,19 +52628,18 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s5UInt8V5WordsVyAdBcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:s5UInt8V5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49787,10 +52651,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5UInt8V5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -49798,21 +52658,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5UInt8V5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5UInt8V5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:s5UInt8V5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49824,10 +52686,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5UInt8V5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -49835,21 +52693,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5UInt8V5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5UInt8V5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:s5UInt8V5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49861,10 +52721,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5UInt8V5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -49872,21 +52728,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5UInt8V5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5UInt8V5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:s5UInt8V5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -49897,7 +52755,6 @@
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -49905,7 +52762,8 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
                   ]
                 },
@@ -49913,10 +52771,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5UInt8V5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -49927,7 +52781,6 @@
                           "kind": "TypeNominal",
                           "name": "Range",
                           "printedName": "Range<Int>",
-                          "usr": "s:Sn",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -49935,25 +52788,28 @@
                               "printedName": "Int",
                               "usr": "s:Si"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sn"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5UInt8V5WordsV7indicesSnySiGvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5UInt8V5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:s5UInt8V5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49967,19 +52823,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s5UInt8V5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:s5UInt8V5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -49993,16 +52848,43 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s5UInt8V5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:s5UInt8V5WordsVySuSicip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s5UInt8V5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50010,16 +52892,16 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5UInt8V5WordsV7Elementa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Index",
               "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:s5UInt8V5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50027,22 +52909,21 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5UInt8V5WordsV5Indexa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s5UInt8V5WordsV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "IndexingIterator",
                   "printedName": "IndexingIterator<UInt8.Words>",
-                  "usr": "s:s16IndexingIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -50050,23 +52931,33 @@
                       "printedName": "UInt8.Words",
                       "usr": "s:s5UInt8V5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s16IndexingIteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5UInt8V5WordsV8Iteratora",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s5UInt8V5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V5wordsAB5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50078,10 +52969,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V5wordsAB5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50089,18 +52976,23 @@
                   "printedName": "UInt8.Words",
                   "usr": "s:s5UInt8V5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V5wordsAB5WordsVvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V5wordsAB5WordsVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Magnitude",
           "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s5UInt8V9Magnitudea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50108,19 +53000,15 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5UInt8V9Magnitudea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V19multipliedFullWidth2byAB4high_AB3lowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50154,19 +53042,18 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V19multipliedFullWidth2byAB4high_AB3lowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_AB3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50213,19 +53100,18 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_AB3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V11byteSwappedABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50237,10 +53123,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V11byteSwappedABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50248,43 +53130,23 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V11byteSwappedABvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "toIntMax",
-          "printedName": "toIntMax()",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V8toIntMaxs5Int64VyF",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V11byteSwappedABvp",
           "moduleName": "Swift",
           "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V6signumAByF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50292,16 +53154,19 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V6signumAByF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s5UInt8V6Stridea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50309,20 +53174,16 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5UInt8V6Stridea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V4fromABs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50336,20 +53197,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5UInt8V4fromABs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50362,19 +53219,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s5UInt8V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50387,16 +53241,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50408,10 +53264,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50419,23 +53271,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V20truncatingBitPatternABs6UInt16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50445,25 +53296,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1aoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V20truncatingBitPatternABs5Int16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50473,25 +53328,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1ooiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V20truncatingBitPatternABs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50501,25 +53360,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1xoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V20truncatingBitPatternABs5Int32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50529,25 +53392,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V3aggoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V20truncatingBitPatternABs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50557,25 +53424,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V3alloiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V20truncatingBitPatternABs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50585,25 +53456,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V20truncatingBitPatternABSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50613,25 +53488,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1roiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V20truncatingBitPatternABSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50641,23 +53520,189 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2leoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V2geoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt8",
+              "printedName": "UInt8",
+              "usr": "s:s5UInt8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5UInt8V1goiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(ascii:)",
-          "declKind": "Constructor",
-          "usr": "s:s5UInt8V5asciiABs7UnicodeO6ScalarV_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50671,16 +53716,18 @@
               "printedName": "Unicode.Scalar",
               "usr": "s:s7UnicodeO6ScalarV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5UInt8V5asciiABs7UnicodeO6ScalarV_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50692,10 +53739,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50703,23 +53746,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:s5UInt8V25customPlaygroundQuickLooks01_cdE0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50731,10 +53771,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5UInt8V25customPlaygroundQuickLooks01_cdE0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50742,53 +53778,58 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5UInt8V25customPlaygroundQuickLooks01_cdE0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5UInt8V25customPlaygroundQuickLooks01_cdE0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s5UInt8V",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Comparable",
+        "UnsignedInteger",
+        "_ExpressibleByBuiltinIntegerLiteral",
+        "BinaryInteger",
+        "LosslessStringConvertible",
+        "Numeric",
+        "CustomStringConvertible",
+        "Strideable",
+        "ExpressibleByIntegerLiteral",
+        "FixedWidthInteger",
+        "Encodable",
+        "Decodable",
+        "Hashable",
+        "Equatable",
+        "_HasCustomAnyHashableRepresentation",
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "_StringElement",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Int8",
       "printedName": "Int8",
-      "declKind": "Struct",
-      "usr": "s:s4Int8V",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Comparable",
-        "SignedInteger",
-        "_ExpressibleByBuiltinIntegerLiteral",
-        "BinaryInteger",
-        "LosslessStringConvertible",
-        "SignedNumeric",
-        "Numeric",
-        "CustomStringConvertible",
-        "Strideable",
-        "ExpressibleByIntegerLiteral",
-        "FixedWidthInteger",
-        "Decodable",
-        "Encodable",
-        "Hashable",
-        "Equatable",
-        "_HasCustomAnyHashableRepresentation",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "IntegerLiteralType",
           "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s4Int8V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -50796,19 +53837,15 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s4Int8V18IntegerLiteralTypea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V10bitPatternABs5UInt8V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50822,25 +53859,57 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s4Int8V10bitPatternABs5UInt8V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s4Int8VyABSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
+              "name": "Optional",
+              "printedName": "Int8?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int8",
+                  "printedName": "Int8",
+                  "usr": "s:s4Int8V"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -50848,85 +53917,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:s4Int8V7exactlyABSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Int8?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int8",
-                  "printedName": "Int8",
-                  "usr": "s:s4Int8V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s4Int8VyABSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int8",
-              "printedName": "Int8",
-              "usr": "s:s4Int8V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50934,7 +53966,8 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -50942,19 +53975,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s4Int8V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8VyABs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -50968,25 +54000,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s4Int8VyABs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V7exactlyABSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int8?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -50994,7 +54024,8 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -51002,19 +54033,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s4Int8V7exactlyABSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51041,19 +54259,18 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51080,19 +54297,18 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51119,19 +54335,18 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51158,19 +54373,18 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51197,20 +54411,204 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2reoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2aeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2oeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2xeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V4aggeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V4alleoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s4Int8V8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51222,11 +54620,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51234,21 +54627,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s4Int8V19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51260,10 +54657,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51271,21 +54664,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s4Int8V20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51297,10 +54692,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51308,21 +54699,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s4Int8V15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51334,10 +54727,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51345,41 +54734,33 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:s4Int8V5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Indices",
               "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:s4Int8V5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<Int>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -51387,24 +54768,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s4Int8V5WordsV7Indicesa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s4Int8V5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Slice",
                   "printedName": "Slice<Int8.Words>",
-                  "usr": "s:s5SliceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -51412,21 +54792,18 @@
                       "printedName": "Int8.Words",
                       "usr": "s:s4Int8V5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s5SliceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s4Int8V5WordsV11SubSequencea",
+              "moduleName": "Swift"
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s4Int8V5WordsVyAdBcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51440,19 +54817,18 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s4Int8V5WordsVyAdBcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:s4Int8V5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51464,10 +54840,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s4Int8V5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -51475,21 +54847,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s4Int8V5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s4Int8V5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:s4Int8V5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51501,10 +54875,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s4Int8V5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -51512,21 +54882,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s4Int8V5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s4Int8V5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:s4Int8V5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51538,10 +54910,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s4Int8V5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -51549,21 +54917,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s4Int8V5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s4Int8V5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:s4Int8V5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -51574,7 +54944,6 @@
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -51582,7 +54951,8 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
                   ]
                 },
@@ -51590,10 +54960,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s4Int8V5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -51604,7 +54970,6 @@
                           "kind": "TypeNominal",
                           "name": "Range",
                           "printedName": "Range<Int>",
-                          "usr": "s:Sn",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -51612,25 +54977,28 @@
                               "printedName": "Int",
                               "usr": "s:Si"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sn"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s4Int8V5WordsV7indicesSnySiGvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s4Int8V5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:s4Int8V5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51644,19 +55012,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s4Int8V5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:s4Int8V5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51670,16 +55037,43 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s4Int8V5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:s4Int8V5WordsVySuSicip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s4Int8V5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51687,16 +55081,16 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s4Int8V5WordsV7Elementa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Index",
               "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:s4Int8V5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51704,22 +55098,21 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s4Int8V5WordsV5Indexa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s4Int8V5WordsV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "IndexingIterator",
                   "printedName": "IndexingIterator<Int8.Words>",
-                  "usr": "s:s16IndexingIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -51727,23 +55120,33 @@
                       "printedName": "Int8.Words",
                       "usr": "s:s4Int8V5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s16IndexingIteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s4Int8V5WordsV8Iteratora",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s4Int8V5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:s4Int8V5wordsAB5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51755,10 +55158,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V5wordsAB5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51766,18 +55165,23 @@
                   "printedName": "Int8.Words",
                   "usr": "s:s4Int8V5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V5wordsAB5WordsVvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V5wordsAB5WordsVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Magnitude",
           "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s4Int8V9Magnitudea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -51785,19 +55189,15 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s4Int8V9Magnitudea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:s4Int8V9magnitudes5UInt8Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51809,10 +55209,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V9magnitudes5UInt8Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51820,21 +55216,23 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V9magnitudes5UInt8Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V9magnitudes5UInt8Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V19multipliedFullWidth2byAB4high_s5UInt8V3lowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51868,19 +55266,18 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V19multipliedFullWidth2byAB4high_s5UInt8V3lowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_s5UInt8V3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51927,19 +55324,18 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_s5UInt8V3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s4Int8V11byteSwappedABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -51951,10 +55347,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V11byteSwappedABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -51962,43 +55354,23 @@
                   "printedName": "Int8",
                   "usr": "s:s4Int8V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V11byteSwappedABvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "toUIntMax",
-          "printedName": "toUIntMax()",
-          "declKind": "Func",
-          "usr": "s:s4Int8V9toUIntMaxs6UInt64VyF",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V11byteSwappedABvp",
           "moduleName": "Swift",
           "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:s4Int8V6signumAByF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52006,16 +55378,19 @@
               "printedName": "Int8",
               "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V6signumAByF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s4Int8V6Stridea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52023,20 +55398,16 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s4Int8V6Stridea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V4fromABs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52050,20 +55421,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s4Int8V4fromABs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52076,19 +55443,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s4Int8V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52101,16 +55465,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s4Int8V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52122,10 +55488,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -52133,23 +55495,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V20truncatingBitPatternABs6UInt16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52159,25 +55520,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1aoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V20truncatingBitPatternABs5Int16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52187,25 +55552,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1ooiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V20truncatingBitPatternABs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52215,25 +55584,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1xoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V20truncatingBitPatternABs5Int32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52243,25 +55616,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V3aggoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V20truncatingBitPatternABs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52271,25 +55648,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V3alloiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V20truncatingBitPatternABs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52299,25 +55680,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V20truncatingBitPatternABSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52327,25 +55712,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1roiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s4Int8V20truncatingBitPatternABSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52355,20 +55744,189 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2leoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V2geoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int8",
+              "printedName": "Int8",
+              "usr": "s:s4Int8V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s4Int8V1goiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s4Int8V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52380,10 +55938,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -52391,23 +55945,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:s4Int8V25customPlaygroundQuickLooks01_cdE0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52419,10 +55970,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s4Int8V25customPlaygroundQuickLooks01_cdE0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -52430,53 +55977,58 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s4Int8V25customPlaygroundQuickLooks01_cdE0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s4Int8V25customPlaygroundQuickLooks01_cdE0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s4Int8V",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Comparable",
+        "SignedInteger",
+        "_ExpressibleByBuiltinIntegerLiteral",
+        "BinaryInteger",
+        "LosslessStringConvertible",
+        "SignedNumeric",
+        "Numeric",
+        "CustomStringConvertible",
+        "Strideable",
+        "ExpressibleByIntegerLiteral",
+        "FixedWidthInteger",
+        "Encodable",
+        "Decodable",
+        "Hashable",
+        "Equatable",
+        "_HasCustomAnyHashableRepresentation",
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UInt16",
       "printedName": "UInt16",
-      "declKind": "Struct",
-      "usr": "s:s6UInt16V",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Comparable",
-        "UnsignedInteger",
-        "_ExpressibleByBuiltinIntegerLiteral",
-        "BinaryInteger",
-        "LosslessStringConvertible",
-        "Numeric",
-        "CustomStringConvertible",
-        "Strideable",
-        "ExpressibleByIntegerLiteral",
-        "FixedWidthInteger",
-        "Decodable",
-        "Encodable",
-        "Hashable",
-        "Equatable",
-        "_HasCustomAnyHashableRepresentation",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "_StringElement",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "IntegerLiteralType",
           "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt16V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -52484,19 +56036,15 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s6UInt16V18IntegerLiteralTypea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V10bitPatternABs5Int16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52510,25 +56058,57 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt16V10bitPatternABs5Int16V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt16VyABSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
+              "name": "Optional",
+              "printedName": "UInt16?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt16",
+                  "printedName": "UInt16",
+                  "usr": "s:s6UInt16V"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -52536,85 +56116,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt16V7exactlyABSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UInt16?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt16",
-                  "printedName": "UInt16",
-                  "usr": "s:s6UInt16V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt16VyABSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt16",
-              "printedName": "UInt16",
-              "usr": "s:s6UInt16V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -52622,7 +56165,8 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -52630,19 +56174,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt16V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16VyABs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52656,25 +56199,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt16VyABs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V7exactlyABSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -52682,7 +56223,8 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -52690,19 +56232,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt16V7exactlyABSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52729,19 +56458,18 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52768,19 +56496,18 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52807,19 +56534,18 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52846,19 +56572,18 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52885,20 +56610,204 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2reoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2aeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2oeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2xeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V4aggeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V4alleoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52910,11 +56819,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -52922,21 +56826,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52948,10 +56856,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -52959,21 +56863,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -52985,10 +56891,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -52996,21 +56898,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -53022,10 +56926,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53033,41 +56933,33 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:s6UInt16V5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Indices",
               "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt16V5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<Int>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -53075,24 +56967,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s6UInt16V5WordsV7Indicesa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt16V5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Slice",
                   "printedName": "Slice<UInt16.Words>",
-                  "usr": "s:s5SliceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -53100,21 +56991,18 @@
                       "printedName": "UInt16.Words",
                       "usr": "s:s6UInt16V5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s5SliceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s6UInt16V5WordsV11SubSequencea",
+              "moduleName": "Swift"
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s6UInt16V5WordsVyAdBcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53128,19 +57016,18 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s6UInt16V5WordsVyAdBcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:s6UInt16V5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53152,10 +57039,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt16V5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -53163,21 +57046,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt16V5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt16V5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:s6UInt16V5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53189,10 +57074,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt16V5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -53200,21 +57081,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt16V5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt16V5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:s6UInt16V5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53226,10 +57109,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt16V5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -53237,21 +57116,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt16V5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt16V5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:s6UInt16V5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -53262,7 +57143,6 @@
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -53270,7 +57150,8 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
                   ]
                 },
@@ -53278,10 +57159,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt16V5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -53292,7 +57169,6 @@
                           "kind": "TypeNominal",
                           "name": "Range",
                           "printedName": "Range<Int>",
-                          "usr": "s:Sn",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -53300,25 +57176,28 @@
                               "printedName": "Int",
                               "usr": "s:Si"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sn"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt16V5WordsV7indicesSnySiGvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt16V5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:s6UInt16V5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53332,19 +57211,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s6UInt16V5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:s6UInt16V5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53358,16 +57236,43 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s6UInt16V5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:s6UInt16V5WordsVySuSicip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt16V5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53375,16 +57280,16 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s6UInt16V5WordsV7Elementa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Index",
               "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt16V5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53392,22 +57297,21 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s6UInt16V5WordsV5Indexa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt16V5WordsV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "IndexingIterator",
                   "printedName": "IndexingIterator<UInt16.Words>",
-                  "usr": "s:s16IndexingIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -53415,23 +57319,33 @@
                       "printedName": "UInt16.Words",
                       "usr": "s:s6UInt16V5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s16IndexingIteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s6UInt16V5WordsV8Iteratora",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s6UInt16V5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V5wordsAB5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -53443,10 +57357,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V5wordsAB5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53454,18 +57364,23 @@
                   "printedName": "UInt16.Words",
                   "usr": "s:s6UInt16V5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V5wordsAB5WordsVvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V5wordsAB5WordsVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Magnitude",
           "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt16V9Magnitudea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53473,19 +57388,15 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s6UInt16V9Magnitudea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V19multipliedFullWidth2byAB4high_AB3lowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -53519,19 +57430,18 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V19multipliedFullWidth2byAB4high_AB3lowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_AB3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -53578,19 +57488,18 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_AB3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V11byteSwappedABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -53602,10 +57511,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V11byteSwappedABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53613,43 +57518,23 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V11byteSwappedABvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "toIntMax",
-          "printedName": "toIntMax()",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V8toIntMaxs5Int64VyF",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V11byteSwappedABvp",
           "moduleName": "Swift",
           "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V6signumAByF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -53657,16 +57542,19 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V6signumAByF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt16V6Stridea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53674,20 +57562,16 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s6UInt16V6Stridea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V4fromABs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -53701,20 +57585,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt16V4fromABs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -53727,19 +57607,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt16V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -53752,16 +57629,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53773,10 +57652,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53784,23 +57659,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V20truncatingBitPatternABs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53810,25 +57684,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1aoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V20truncatingBitPatternABs5Int32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53838,25 +57716,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1ooiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V20truncatingBitPatternABs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53866,25 +57748,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1xoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V20truncatingBitPatternABs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53894,25 +57780,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V3aggoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V20truncatingBitPatternABSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53922,25 +57812,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V3alloiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt16V20truncatingBitPatternABSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53950,20 +57844,253 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1roiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2leoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V2geoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt16",
+              "printedName": "UInt16",
+              "usr": "s:s6UInt16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt16V1goiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -53975,10 +58102,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -53986,23 +58109,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:s6UInt16V25customPlaygroundQuickLooks01_cdE0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54014,10 +58134,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt16V25customPlaygroundQuickLooks01_cdE0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54025,53 +58141,58 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt16V25customPlaygroundQuickLooks01_cdE0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt16V25customPlaygroundQuickLooks01_cdE0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s6UInt16V",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Comparable",
+        "UnsignedInteger",
+        "_ExpressibleByBuiltinIntegerLiteral",
+        "BinaryInteger",
+        "LosslessStringConvertible",
+        "Numeric",
+        "CustomStringConvertible",
+        "Strideable",
+        "ExpressibleByIntegerLiteral",
+        "FixedWidthInteger",
+        "Encodable",
+        "Decodable",
+        "Hashable",
+        "Equatable",
+        "_HasCustomAnyHashableRepresentation",
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "_StringElement",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Int16",
       "printedName": "Int16",
-      "declKind": "Struct",
-      "usr": "s:s5Int16V",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Comparable",
-        "SignedInteger",
-        "_ExpressibleByBuiltinIntegerLiteral",
-        "BinaryInteger",
-        "LosslessStringConvertible",
-        "SignedNumeric",
-        "Numeric",
-        "CustomStringConvertible",
-        "Strideable",
-        "ExpressibleByIntegerLiteral",
-        "FixedWidthInteger",
-        "Decodable",
-        "Encodable",
-        "Hashable",
-        "Equatable",
-        "_HasCustomAnyHashableRepresentation",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "IntegerLiteralType",
           "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int16V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -54079,19 +58200,15 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5Int16V18IntegerLiteralTypea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V10bitPatternABs6UInt16V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54105,25 +58222,57 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int16V10bitPatternABs6UInt16V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int16VyABSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
+              "name": "Optional",
+              "printedName": "Int16?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int16",
+                  "printedName": "Int16",
+                  "usr": "s:s5Int16V"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -54131,85 +58280,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int16V7exactlyABSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Int16?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int16",
-                  "printedName": "Int16",
-                  "usr": "s:s5Int16V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int16VyABSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int16",
-              "printedName": "Int16",
-              "usr": "s:s5Int16V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54217,7 +58329,8 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -54225,19 +58338,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int16V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16VyABs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54251,25 +58363,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int16VyABs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V7exactlyABSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int16?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54277,7 +58387,8 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -54285,19 +58396,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int16V7exactlyABSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54324,19 +58622,18 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54363,19 +58660,18 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54402,19 +58698,18 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54441,19 +58736,18 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54480,20 +58774,204 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2reoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2aeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2oeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2xeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V4aggeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V4alleoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s5Int16V8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54505,11 +58983,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54517,21 +58990,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int16V19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54543,10 +59020,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54554,21 +59027,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int16V20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54580,10 +59055,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54591,21 +59062,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int16V15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -54617,10 +59090,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54628,41 +59097,33 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:s5Int16V5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Indices",
               "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int16V5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<Int>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -54670,24 +59131,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5Int16V5WordsV7Indicesa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int16V5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Slice",
                   "printedName": "Slice<Int16.Words>",
-                  "usr": "s:s5SliceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -54695,21 +59155,18 @@
                       "printedName": "Int16.Words",
                       "usr": "s:s5Int16V5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s5SliceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5Int16V5WordsV11SubSequencea",
+              "moduleName": "Swift"
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s5Int16V5WordsVyAdBcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54723,19 +59180,18 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s5Int16V5WordsVyAdBcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:s5Int16V5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54747,10 +59203,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int16V5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -54758,21 +59210,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int16V5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int16V5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:s5Int16V5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54784,10 +59238,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int16V5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -54795,21 +59245,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int16V5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int16V5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:s5Int16V5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54821,10 +59273,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int16V5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -54832,21 +59280,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int16V5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int16V5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:s5Int16V5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -54857,7 +59307,6 @@
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -54865,7 +59314,8 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
                   ]
                 },
@@ -54873,10 +59323,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int16V5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -54887,7 +59333,6 @@
                           "kind": "TypeNominal",
                           "name": "Range",
                           "printedName": "Range<Int>",
-                          "usr": "s:Sn",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -54895,25 +59340,28 @@
                               "printedName": "Int",
                               "usr": "s:Si"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sn"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int16V5WordsV7indicesSnySiGvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int16V5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:s5Int16V5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54927,19 +59375,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s5Int16V5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:s5Int16V5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54953,16 +59400,43 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s5Int16V5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:s5Int16V5WordsVySuSicip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int16V5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54970,16 +59444,16 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5Int16V5WordsV7Elementa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Index",
               "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int16V5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -54987,22 +59461,21 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5Int16V5WordsV5Indexa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int16V5WordsV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "IndexingIterator",
                   "printedName": "IndexingIterator<Int16.Words>",
-                  "usr": "s:s16IndexingIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -55010,23 +59483,33 @@
                       "printedName": "Int16.Words",
                       "usr": "s:s5Int16V5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s16IndexingIteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5Int16V5WordsV8Iteratora",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s5Int16V5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:s5Int16V5wordsAB5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55038,10 +59521,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V5wordsAB5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55049,18 +59528,23 @@
                   "printedName": "Int16.Words",
                   "usr": "s:s5Int16V5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V5wordsAB5WordsVvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V5wordsAB5WordsVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Magnitude",
           "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int16V9Magnitudea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55068,19 +59552,15 @@
               "printedName": "UInt16",
               "usr": "s:s6UInt16V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5Int16V9Magnitudea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:s5Int16V9magnitudes6UInt16Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55092,10 +59572,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V9magnitudes6UInt16Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55103,21 +59579,23 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V9magnitudes6UInt16Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V9magnitudes6UInt16Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V19multipliedFullWidth2byAB4high_s6UInt16V3lowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55151,19 +59629,18 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V19multipliedFullWidth2byAB4high_s6UInt16V3lowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_s6UInt16V3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55210,19 +59687,18 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_s6UInt16V3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s5Int16V11byteSwappedABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55234,10 +59710,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V11byteSwappedABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55245,43 +59717,23 @@
                   "printedName": "Int16",
                   "usr": "s:s5Int16V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V11byteSwappedABvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "toUIntMax",
-          "printedName": "toUIntMax()",
-          "declKind": "Func",
-          "usr": "s:s5Int16V9toUIntMaxs6UInt64VyF",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V11byteSwappedABvp",
           "moduleName": "Swift",
           "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:s5Int16V6signumAByF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55289,16 +59741,19 @@
               "printedName": "Int16",
               "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V6signumAByF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int16V6Stridea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55306,20 +59761,16 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5Int16V6Stridea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V4fromABs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55333,20 +59784,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int16V4fromABs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55359,19 +59806,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s5Int16V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55384,16 +59828,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s5Int16V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55405,10 +59851,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55416,23 +59858,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V20truncatingBitPatternABs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55442,25 +59883,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1aoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V20truncatingBitPatternABs5Int32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55470,25 +59915,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1ooiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V20truncatingBitPatternABs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55498,25 +59947,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1xoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V20truncatingBitPatternABs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55526,25 +59979,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V3aggoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V20truncatingBitPatternABSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55554,25 +60011,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V3alloiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int16V20truncatingBitPatternABSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55582,20 +60043,253 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1roiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2leoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V2geoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int16",
+              "printedName": "Int16",
+              "usr": "s:s5Int16V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int16V1goiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s5Int16V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55607,10 +60301,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55618,23 +60308,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:s5Int16V25customPlaygroundQuickLooks01_cdE0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55646,10 +60333,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int16V25customPlaygroundQuickLooks01_cdE0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55657,52 +60340,58 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int16V25customPlaygroundQuickLooks01_cdE0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int16V25customPlaygroundQuickLooks01_cdE0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "UInt32",
-      "printedName": "UInt32",
+      ],
       "declKind": "Struct",
-      "usr": "s:s6UInt32V",
-      "location": "",
+      "usr": "s:s5Int16V",
       "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "Comparable",
-        "UnsignedInteger",
+        "SignedInteger",
         "_ExpressibleByBuiltinIntegerLiteral",
         "BinaryInteger",
         "LosslessStringConvertible",
+        "SignedNumeric",
         "Numeric",
         "CustomStringConvertible",
         "Strideable",
         "ExpressibleByIntegerLiteral",
         "FixedWidthInteger",
-        "Decodable",
         "Encodable",
+        "Decodable",
         "Hashable",
         "Equatable",
         "_HasCustomAnyHashableRepresentation",
         "CustomReflectable",
         "_CustomPlaygroundQuickLookable",
         "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "UInt32",
+      "printedName": "UInt32",
       "children": [
         {
           "kind": "TypeAlias",
           "name": "IntegerLiteralType",
           "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt32V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -55710,19 +60399,15 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s6UInt32V18IntegerLiteralTypea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32V10bitPatternABs5Int32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55736,25 +60421,57 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt32V10bitPatternABs5Int32V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt32VyABSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
+              "name": "Optional",
+              "printedName": "UInt32?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt32",
+                  "printedName": "UInt32",
+                  "usr": "s:s6UInt32V"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -55762,85 +60479,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt32V7exactlyABSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UInt32?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt32",
-                  "printedName": "UInt32",
-                  "usr": "s:s6UInt32V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt32VyABSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt32",
-              "printedName": "UInt32",
-              "usr": "s:s6UInt32V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55848,7 +60528,8 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -55856,19 +60537,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt32V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32VyABs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55882,25 +60562,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt32VyABs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32V7exactlyABSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -55908,7 +60586,8 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -55916,19 +60595,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt32V7exactlyABSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55955,19 +60821,18 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -55994,19 +60859,18 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56033,19 +60897,18 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56072,19 +60935,18 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56111,20 +60973,204 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2reoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2aeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2oeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2xeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V4aggeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V4alleoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56136,11 +61182,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56148,21 +61189,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56174,10 +61219,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56185,21 +61226,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56211,10 +61254,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56222,21 +61261,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56248,10 +61289,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56259,41 +61296,33 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:s6UInt32V5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Indices",
               "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt32V5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<Int>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -56301,24 +61330,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s6UInt32V5WordsV7Indicesa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt32V5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Slice",
                   "printedName": "Slice<UInt32.Words>",
-                  "usr": "s:s5SliceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -56326,21 +61354,18 @@
                       "printedName": "UInt32.Words",
                       "usr": "s:s6UInt32V5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s5SliceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s6UInt32V5WordsV11SubSequencea",
+              "moduleName": "Swift"
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s6UInt32V5WordsVyAdBcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56354,19 +61379,18 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s6UInt32V5WordsVyAdBcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:s6UInt32V5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56378,10 +61402,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt32V5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -56389,21 +61409,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt32V5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt32V5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:s6UInt32V5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56415,10 +61437,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt32V5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -56426,21 +61444,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt32V5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt32V5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:s6UInt32V5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56452,10 +61472,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt32V5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -56463,21 +61479,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt32V5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt32V5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:s6UInt32V5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -56488,7 +61506,6 @@
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -56496,7 +61513,8 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
                   ]
                 },
@@ -56504,10 +61522,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt32V5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -56518,7 +61532,6 @@
                           "kind": "TypeNominal",
                           "name": "Range",
                           "printedName": "Range<Int>",
-                          "usr": "s:Sn",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -56526,25 +61539,28 @@
                               "printedName": "Int",
                               "usr": "s:Si"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sn"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt32V5WordsV7indicesSnySiGvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt32V5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:s6UInt32V5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56558,19 +61574,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s6UInt32V5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:s6UInt32V5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56584,16 +61599,43 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s6UInt32V5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:s6UInt32V5WordsVySuSicip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt32V5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56601,16 +61643,16 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s6UInt32V5WordsV7Elementa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Index",
               "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt32V5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56618,22 +61660,21 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s6UInt32V5WordsV5Indexa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt32V5WordsV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "IndexingIterator",
                   "printedName": "IndexingIterator<UInt32.Words>",
-                  "usr": "s:s16IndexingIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -56641,23 +61682,33 @@
                       "printedName": "UInt32.Words",
                       "usr": "s:s6UInt32V5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s16IndexingIteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s6UInt32V5WordsV8Iteratora",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s6UInt32V5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V5wordsAB5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56669,10 +61720,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V5wordsAB5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56680,18 +61727,23 @@
                   "printedName": "UInt32.Words",
                   "usr": "s:s6UInt32V5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V5wordsAB5WordsVvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V5wordsAB5WordsVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Magnitude",
           "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt32V9Magnitudea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -56699,19 +61751,15 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s6UInt32V9Magnitudea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V19multipliedFullWidth2byAB4high_AB3lowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56745,19 +61793,18 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V19multipliedFullWidth2byAB4high_AB3lowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_AB3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56804,19 +61851,18 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_AB3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V11byteSwappedABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56828,10 +61874,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V11byteSwappedABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -56839,43 +61881,23 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V11byteSwappedABvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "toIntMax",
-          "printedName": "toIntMax()",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V8toIntMaxs5Int64VyF",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V11byteSwappedABvp",
           "moduleName": "Swift",
           "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V6signumAByF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56883,16 +61905,19 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V6signumAByF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt32V6Stridea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -56900,20 +61925,16 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s6UInt32V6Stridea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32V4fromABs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56927,20 +61948,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt32V4fromABs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56953,19 +61970,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt32V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -56978,16 +61992,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -56999,10 +62015,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57010,23 +62022,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32V20truncatingBitPatternABs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -57036,25 +62047,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1aoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32V20truncatingBitPatternABs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -57064,25 +62079,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1ooiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32V20truncatingBitPatternABSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -57092,25 +62111,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1xoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32V20truncatingBitPatternABSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -57120,23 +62143,317 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V3aggoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V3alloiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1roiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2leoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V2geoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt32",
+              "printedName": "UInt32",
+              "usr": "s:s6UInt32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt32V1goiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt32VyABs7UnicodeO6ScalarVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57150,16 +62467,18 @@
               "printedName": "Unicode.Scalar",
               "usr": "s:s7UnicodeO6ScalarV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt32VyABs7UnicodeO6ScalarVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -57171,10 +62490,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57182,23 +62497,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:s6UInt32V25customPlaygroundQuickLooks01_cdE0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57210,10 +62522,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt32V25customPlaygroundQuickLooks01_cdE0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57221,53 +62529,57 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt32V25customPlaygroundQuickLooks01_cdE0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt32V25customPlaygroundQuickLooks01_cdE0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "Int32",
-      "printedName": "Int32",
+      ],
       "declKind": "Struct",
-      "usr": "s:s5Int32V",
-      "location": "",
+      "usr": "s:s6UInt32V",
       "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "Comparable",
-        "SignedInteger",
+        "UnsignedInteger",
         "_ExpressibleByBuiltinIntegerLiteral",
         "BinaryInteger",
         "LosslessStringConvertible",
-        "SignedNumeric",
         "Numeric",
         "CustomStringConvertible",
         "Strideable",
         "ExpressibleByIntegerLiteral",
         "FixedWidthInteger",
-        "Decodable",
         "Encodable",
+        "Decodable",
         "Hashable",
         "Equatable",
         "_HasCustomAnyHashableRepresentation",
         "CustomReflectable",
         "_CustomPlaygroundQuickLookable",
         "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Int32",
+      "printedName": "Int32",
       "children": [
         {
           "kind": "TypeAlias",
           "name": "IntegerLiteralType",
           "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int32V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -57275,19 +62587,15 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5Int32V18IntegerLiteralTypea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32V10bitPatternABs6UInt32V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57301,25 +62609,57 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int32V10bitPatternABs6UInt32V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int32VyABSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
+              "name": "Optional",
+              "printedName": "Int32?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int32",
+                  "printedName": "Int32",
+                  "usr": "s:s5Int32V"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -57327,85 +62667,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int32V7exactlyABSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Int32?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int32",
-                  "printedName": "Int32",
-                  "usr": "s:s5Int32V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int32VyABSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int32",
-              "printedName": "Int32",
-              "usr": "s:s5Int32V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57413,7 +62716,8 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -57421,19 +62725,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int32V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32VyABs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57447,25 +62750,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int32VyABs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32V7exactlyABSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int32?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57473,7 +62774,8 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -57481,19 +62783,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int32V7exactlyABSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57520,19 +63009,18 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57559,19 +63047,18 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57598,19 +63085,18 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57637,19 +63123,18 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57676,20 +63161,204 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2reoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2aeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2oeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2xeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V4aggeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V4alleoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s5Int32V8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57701,11 +63370,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57713,21 +63377,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int32V19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57739,10 +63407,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57750,21 +63414,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int32V20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57776,10 +63442,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57787,21 +63449,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int32V15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -57813,10 +63477,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57824,41 +63484,33 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:s5Int32V5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Indices",
               "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int32V5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<Int>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -57866,24 +63518,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5Int32V5WordsV7Indicesa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int32V5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Slice",
                   "printedName": "Slice<Int32.Words>",
-                  "usr": "s:s5SliceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -57891,21 +63542,18 @@
                       "printedName": "Int32.Words",
                       "usr": "s:s5Int32V5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s5SliceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5Int32V5WordsV11SubSequencea",
+              "moduleName": "Swift"
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s5Int32V5WordsVyAdBcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57919,19 +63567,18 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s5Int32V5WordsVyAdBcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:s5Int32V5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57943,10 +63590,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int32V5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -57954,21 +63597,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int32V5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int32V5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:s5Int32V5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -57980,10 +63625,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int32V5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -57991,21 +63632,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int32V5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int32V5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:s5Int32V5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58017,10 +63660,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int32V5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -58028,21 +63667,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int32V5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int32V5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:s5Int32V5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -58053,7 +63694,6 @@
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -58061,7 +63701,8 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
                   ]
                 },
@@ -58069,10 +63710,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int32V5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -58083,7 +63720,6 @@
                           "kind": "TypeNominal",
                           "name": "Range",
                           "printedName": "Range<Int>",
-                          "usr": "s:Sn",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -58091,25 +63727,28 @@
                               "printedName": "Int",
                               "usr": "s:Si"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sn"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int32V5WordsV7indicesSnySiGvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int32V5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:s5Int32V5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58123,19 +63762,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s5Int32V5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:s5Int32V5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58149,16 +63787,43 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s5Int32V5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:s5Int32V5WordsVySuSicip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int32V5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58166,16 +63831,16 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5Int32V5WordsV7Elementa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Index",
               "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int32V5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58183,22 +63848,21 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5Int32V5WordsV5Indexa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int32V5WordsV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "IndexingIterator",
                   "printedName": "IndexingIterator<Int32.Words>",
-                  "usr": "s:s16IndexingIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -58206,23 +63870,33 @@
                       "printedName": "Int32.Words",
                       "usr": "s:s5Int32V5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s16IndexingIteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5Int32V5WordsV8Iteratora",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s5Int32V5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:s5Int32V5wordsAB5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58234,10 +63908,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V5wordsAB5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58245,18 +63915,23 @@
                   "printedName": "Int32.Words",
                   "usr": "s:s5Int32V5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V5wordsAB5WordsVvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V5wordsAB5WordsVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Magnitude",
           "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int32V9Magnitudea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -58264,19 +63939,15 @@
               "printedName": "UInt32",
               "usr": "s:s6UInt32V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5Int32V9Magnitudea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:s5Int32V9magnitudes6UInt32Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58288,10 +63959,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V9magnitudes6UInt32Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58299,21 +63966,23 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V9magnitudes6UInt32Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V9magnitudes6UInt32Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V19multipliedFullWidth2byAB4high_s6UInt32V3lowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58347,19 +64016,18 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V19multipliedFullWidth2byAB4high_s6UInt32V3lowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_s6UInt32V3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58406,19 +64074,18 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_s6UInt32V3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s5Int32V11byteSwappedABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58430,10 +64097,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V11byteSwappedABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58441,43 +64104,23 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V11byteSwappedABvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "toUIntMax",
-          "printedName": "toUIntMax()",
-          "declKind": "Func",
-          "usr": "s:s5Int32V9toUIntMaxs6UInt64VyF",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V11byteSwappedABvp",
           "moduleName": "Swift",
           "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:s5Int32V6signumAByF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58485,16 +64128,19 @@
               "printedName": "Int32",
               "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V6signumAByF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int32V6Stridea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -58502,20 +64148,16 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5Int32V6Stridea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32V4fromABs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58529,20 +64171,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int32V4fromABs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58555,19 +64193,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s5Int32V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58580,16 +64215,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s5Int32V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -58601,10 +64238,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58612,23 +64245,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32V20truncatingBitPatternABs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -58638,25 +64270,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1aoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32V20truncatingBitPatternABs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -58666,25 +64302,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1ooiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32V20truncatingBitPatternABSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -58694,25 +64334,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1xoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int32V20truncatingBitPatternABSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -58722,20 +64366,317 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V3aggoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V3alloiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1roiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2leoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V2geoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int32",
+              "printedName": "Int32",
+              "usr": "s:s5Int32V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int32V1goiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s5Int32V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -58747,10 +64688,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58758,23 +64695,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:s5Int32V25customPlaygroundQuickLooks01_cdE0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58786,10 +64720,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int32V25customPlaygroundQuickLooks01_cdE0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58797,53 +64727,58 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int32V25customPlaygroundQuickLooks01_cdE0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int32V25customPlaygroundQuickLooks01_cdE0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s5Int32V",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Comparable",
+        "SignedInteger",
+        "_ExpressibleByBuiltinIntegerLiteral",
+        "BinaryInteger",
+        "LosslessStringConvertible",
+        "SignedNumeric",
+        "Numeric",
+        "CustomStringConvertible",
+        "Strideable",
+        "ExpressibleByIntegerLiteral",
+        "FixedWidthInteger",
+        "Encodable",
+        "Decodable",
+        "Hashable",
+        "Equatable",
+        "_HasCustomAnyHashableRepresentation",
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UInt64",
       "printedName": "UInt64",
-      "declKind": "Struct",
-      "usr": "s:s6UInt64V",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Comparable",
-        "UnsignedInteger",
-        "_ExpressibleByBuiltinIntegerLiteral",
-        "BinaryInteger",
-        "LosslessStringConvertible",
-        "Numeric",
-        "CustomStringConvertible",
-        "Strideable",
-        "ExpressibleByIntegerLiteral",
-        "FixedWidthInteger",
-        "Decodable",
-        "Encodable",
-        "Hashable",
-        "Equatable",
-        "_HasCustomAnyHashableRepresentation",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "CVarArg",
-        "_CVarArgAligned"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "IntegerLiteralType",
           "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt64V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -58851,19 +64786,15 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s6UInt64V18IntegerLiteralTypea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt64V10bitPatternABs5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -58877,25 +64808,57 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt64V10bitPatternABs5Int64V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt64VyABSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "Optional",
+              "printedName": "UInt64?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt64",
+                  "printedName": "UInt64",
+                  "usr": "s:s6UInt64V"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -58903,85 +64866,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt64V7exactlyABSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UInt64?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt64",
-                  "printedName": "UInt64",
-                  "usr": "s:s6UInt64V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s6UInt64VyABSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt64V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -58989,7 +64915,8 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -58997,19 +64924,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt64V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt64VyABs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59023,25 +64949,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt64VyABs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt64V7exactlyABSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59049,7 +64973,8 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -59057,19 +64982,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt64V7exactlyABSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59096,19 +65208,18 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59135,19 +65246,18 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59174,19 +65284,18 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59213,19 +65322,18 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59252,20 +65360,204 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2reoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2aeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2oeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2xeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V4aggeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V4alleoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59277,11 +65569,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59289,21 +65576,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59315,10 +65606,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59326,21 +65613,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59352,10 +65641,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59363,21 +65648,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59389,10 +65676,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59400,41 +65683,33 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:s6UInt64V5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Indices",
               "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt64V5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<Int>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -59442,24 +65717,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s6UInt64V5WordsV7Indicesa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt64V5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Slice",
                   "printedName": "Slice<UInt64.Words>",
-                  "usr": "s:s5SliceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -59467,21 +65741,18 @@
                       "printedName": "UInt64.Words",
                       "usr": "s:s6UInt64V5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s5SliceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s6UInt64V5WordsV11SubSequencea",
+              "moduleName": "Swift"
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s6UInt64V5WordsVyAdBcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59495,19 +65766,18 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s6UInt64V5WordsVyAdBcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:s6UInt64V5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59519,10 +65789,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt64V5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -59530,21 +65796,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt64V5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt64V5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:s6UInt64V5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59556,10 +65824,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt64V5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -59567,21 +65831,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt64V5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt64V5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:s6UInt64V5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59593,10 +65859,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt64V5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -59604,21 +65866,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt64V5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt64V5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:s6UInt64V5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -59629,7 +65893,6 @@
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -59637,7 +65900,8 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
                   ]
                 },
@@ -59645,10 +65909,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6UInt64V5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -59659,7 +65919,6 @@
                           "kind": "TypeNominal",
                           "name": "Range",
                           "printedName": "Range<Int>",
-                          "usr": "s:Sn",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -59667,25 +65926,28 @@
                               "printedName": "Int",
                               "usr": "s:Si"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sn"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6UInt64V5WordsV7indicesSnySiGvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s6UInt64V5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:s6UInt64V5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59699,19 +65961,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s6UInt64V5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:s6UInt64V5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59725,16 +65986,43 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s6UInt64V5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:s6UInt64V5WordsVySuSicip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt64V5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59742,16 +66030,16 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s6UInt64V5WordsV7Elementa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Index",
               "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt64V5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59759,22 +66047,21 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s6UInt64V5WordsV5Indexa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s6UInt64V5WordsV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "IndexingIterator",
                   "printedName": "IndexingIterator<UInt64.Words>",
-                  "usr": "s:s16IndexingIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -59782,23 +66069,33 @@
                       "printedName": "UInt64.Words",
                       "usr": "s:s6UInt64V5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s16IndexingIteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s6UInt64V5WordsV8Iteratora",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s6UInt64V5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V5wordsAB5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59810,10 +66107,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V5wordsAB5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59821,18 +66114,23 @@
                   "printedName": "UInt64.Words",
                   "usr": "s:s6UInt64V5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V5wordsAB5WordsVvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V5wordsAB5WordsVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Magnitude",
           "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt64V9Magnitudea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -59840,19 +66138,15 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s6UInt64V9Magnitudea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V19multipliedFullWidth2byAB4high_AB3lowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59886,19 +66180,18 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V19multipliedFullWidth2byAB4high_AB3lowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_AB3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59945,19 +66238,18 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_AB3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V11byteSwappedABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -59969,10 +66261,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V11byteSwappedABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -59980,43 +66268,23 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V11byteSwappedABvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "toIntMax",
-          "printedName": "toIntMax()",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V8toIntMaxs5Int64VyF",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V11byteSwappedABvp",
           "moduleName": "Swift",
           "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V6signumAByF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60024,16 +66292,19 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V6signumAByF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s6UInt64V6Stridea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -60041,20 +66312,16 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s6UInt64V6Stridea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt64V4fromABs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60068,20 +66335,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt64V4fromABs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60094,19 +66357,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s6UInt64V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60119,16 +66379,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -60140,10 +66402,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60151,21 +66409,438 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1aoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1ooiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1xoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V3aggoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V3alloiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1roiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2leoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V2geoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt64",
+              "printedName": "UInt64",
+              "usr": "s:s6UInt64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s6UInt64V1goiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s6UInt64VyABs7UnicodeO6ScalarVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60179,16 +66854,18 @@
               "printedName": "Unicode.Scalar",
               "usr": "s:s7UnicodeO6ScalarV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6UInt64VyABs7UnicodeO6ScalarVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -60200,10 +66877,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60211,23 +66884,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:s6UInt64V25customPlaygroundQuickLooks01_cdE0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60239,10 +66909,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6UInt64V25customPlaygroundQuickLooks01_cdE0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60250,34 +66916,40 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6UInt64V25customPlaygroundQuickLooks01_cdE0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s6UInt64V25customPlaygroundQuickLooks01_cdE0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "Int64",
-      "printedName": "Int64",
+      ],
       "declKind": "Struct",
-      "usr": "s:s5Int64V",
-      "location": "",
+      "usr": "s:s6UInt64V",
       "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "Comparable",
-        "SignedInteger",
+        "UnsignedInteger",
         "_ExpressibleByBuiltinIntegerLiteral",
         "BinaryInteger",
         "LosslessStringConvertible",
-        "SignedNumeric",
         "Numeric",
         "CustomStringConvertible",
         "Strideable",
         "ExpressibleByIntegerLiteral",
         "FixedWidthInteger",
-        "Decodable",
         "Encodable",
+        "Decodable",
         "Hashable",
         "Equatable",
         "_HasCustomAnyHashableRepresentation",
@@ -60285,19 +66957,17 @@
         "_CustomPlaygroundQuickLookable",
         "CVarArg",
         "_CVarArgAligned"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Int64",
+      "printedName": "Int64",
       "children": [
         {
           "kind": "TypeAlias",
           "name": "IntegerLiteralType",
           "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int64V18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -60305,19 +66975,15 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5Int64V18IntegerLiteralTypea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int64V10bitPatternABs6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60331,25 +66997,57 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int64V10bitPatternABs6UInt64V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int64VyABSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "Optional",
+              "printedName": "Int64?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int64",
+                  "printedName": "Int64",
+                  "usr": "s:s5Int64V"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -60357,85 +67055,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int64V7exactlyABSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Int64?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int64",
-                  "printedName": "Int64",
-                  "usr": "s:s5Int64V"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s5Int64VyABSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int64V7exactlyABSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60443,7 +67104,8 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -60451,19 +67113,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int64V7exactlyABSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int64VyABs7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60477,25 +67138,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int64VyABs7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int64V7exactlyABSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int64?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60503,7 +67162,8 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -60511,19 +67171,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int64V7exactlyABSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2peoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2seoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2meoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2deoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60550,19 +67397,18 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V24dividedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60589,19 +67435,18 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V26remainderReportingOverflow10dividingByAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60628,19 +67473,18 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V23addingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60667,19 +67511,18 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V28subtractingReportingOverflowyAB12partialValue_Sb8overflowtABF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60706,20 +67549,204 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V27multipliedReportingOverflow2byAB12partialValue_Sb8overflowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2reoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2aeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2oeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2xeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V4aggeoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V4alleoiyyABz_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:s5Int64V8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60731,11 +67758,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60743,21 +67765,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int64V19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60769,10 +67795,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60780,21 +67802,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int64V20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60806,10 +67830,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60817,21 +67837,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:s5Int64V15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -60843,10 +67865,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60854,41 +67872,33 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:s5Int64V5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Indices",
               "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int64V5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<Int>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -60896,24 +67906,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5Int64V5WordsV7Indicesa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int64V5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Slice",
                   "printedName": "Slice<Int64.Words>",
-                  "usr": "s:s5SliceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -60921,21 +67930,18 @@
                       "printedName": "Int64.Words",
                       "usr": "s:s5Int64V5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s5SliceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5Int64V5WordsV11SubSequencea",
+              "moduleName": "Swift"
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s5Int64V5WordsVyAdBcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60949,19 +67955,18 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s5Int64V5WordsVyAdBcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:s5Int64V5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -60973,10 +67978,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int64V5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -60984,21 +67985,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int64V5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int64V5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:s5Int64V5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61010,10 +68013,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int64V5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -61021,21 +68020,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int64V5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int64V5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:s5Int64V5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61047,10 +68048,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int64V5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -61058,21 +68055,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int64V5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int64V5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:s5Int64V5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -61083,7 +68082,6 @@
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -61091,7 +68089,8 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
                   ]
                 },
@@ -61099,10 +68098,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s5Int64V5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -61113,7 +68108,6 @@
                           "kind": "TypeNominal",
                           "name": "Range",
                           "printedName": "Range<Int>",
-                          "usr": "s:Sn",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -61121,25 +68115,28 @@
                               "printedName": "Int",
                               "usr": "s:Si"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sn"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s5Int64V5WordsV7indicesSnySiGvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s5Int64V5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:s5Int64V5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61153,19 +68150,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s5Int64V5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:s5Int64V5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61179,16 +68175,43 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s5Int64V5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:s5Int64V5WordsVySuSicip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int64V5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61196,16 +68219,16 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5Int64V5WordsV7Elementa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Index",
               "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int64V5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61213,22 +68236,21 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5Int64V5WordsV5Indexa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s5Int64V5WordsV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "IndexingIterator",
                   "printedName": "IndexingIterator<Int64.Words>",
-                  "usr": "s:s16IndexingIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -61236,23 +68258,33 @@
                       "printedName": "Int64.Words",
                       "usr": "s:s5Int64V5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s16IndexingIteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s5Int64V5WordsV8Iteratora",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s5Int64V5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:s5Int64V5wordsAB5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61264,10 +68296,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V5wordsAB5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61275,18 +68303,23 @@
                   "printedName": "Int64.Words",
                   "usr": "s:s5Int64V5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V5wordsAB5WordsVvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V5wordsAB5WordsVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Magnitude",
           "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int64V9Magnitudea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -61294,19 +68327,15 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5Int64V9Magnitudea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:s5Int64V9magnitudes6UInt64Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61318,10 +68347,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V9magnitudes6UInt64Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61329,21 +68354,23 @@
                   "printedName": "UInt64",
                   "usr": "s:s6UInt64V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V9magnitudes6UInt64Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V9magnitudes6UInt64Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V19multipliedFullWidth2byAB4high_s6UInt64V3lowtAB_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61377,19 +68404,18 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V19multipliedFullWidth2byAB4high_s6UInt64V3lowtAB_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_s6UInt64V3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61436,19 +68462,18 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V17dividingFullWidthyAB8quotient_AB9remaindertAB4high_s6UInt64V3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:s5Int64V11byteSwappedABvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61460,10 +68485,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V11byteSwappedABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61471,43 +68492,23 @@
                   "printedName": "Int64",
                   "usr": "s:s5Int64V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V11byteSwappedABvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "toUIntMax",
-          "printedName": "toUIntMax()",
-          "declKind": "Func",
-          "usr": "s:s5Int64V9toUIntMaxs6UInt64VyF",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V11byteSwappedABvp",
           "moduleName": "Swift",
           "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:s5Int64V6signumAByF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61515,16 +68516,19 @@
               "printedName": "Int64",
               "usr": "s:s5Int64V"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V6signumAByF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:s5Int64V6Stridea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -61532,20 +68536,16 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5Int64V6Stridea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:s5Int64V4fromABs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61559,20 +68559,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5Int64V4fromABs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61585,19 +68581,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s5Int64V4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61610,16 +68603,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s5Int64V9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -61631,10 +68626,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61642,18 +68633,438 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1aoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1ooiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1xoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V3aggoiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V3alloiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1doiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1roiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1poiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1soiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1moiyA2B_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2leoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V2geoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int64",
+              "printedName": "Int64",
+              "usr": "s:s5Int64V"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5Int64V1goiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s5Int64V12customMirrors0C0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -61665,10 +69076,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V12customMirrors0C0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61676,23 +69083,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V12customMirrors0C0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V12customMirrors0C0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:s5Int64V25customPlaygroundQuickLooks01_cdE0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61704,10 +69108,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5Int64V25customPlaygroundQuickLooks01_cdE0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61715,52 +69115,59 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5Int64V25customPlaygroundQuickLooks01_cdE0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5Int64V25customPlaygroundQuickLooks01_cdE0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s5Int64V",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Comparable",
+        "SignedInteger",
+        "_ExpressibleByBuiltinIntegerLiteral",
+        "BinaryInteger",
+        "LosslessStringConvertible",
+        "SignedNumeric",
+        "Numeric",
+        "CustomStringConvertible",
+        "Strideable",
+        "ExpressibleByIntegerLiteral",
+        "FixedWidthInteger",
+        "Encodable",
+        "Decodable",
+        "Hashable",
+        "Equatable",
+        "_HasCustomAnyHashableRepresentation",
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "CVarArg",
+        "_CVarArgAligned"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UInt",
       "printedName": "UInt",
-      "declKind": "Struct",
-      "usr": "s:Su",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Comparable",
-        "UnsignedInteger",
-        "_ExpressibleByBuiltinIntegerLiteral",
-        "BinaryInteger",
-        "LosslessStringConvertible",
-        "Numeric",
-        "CustomStringConvertible",
-        "Strideable",
-        "ExpressibleByIntegerLiteral",
-        "FixedWidthInteger",
-        "Decodable",
-        "Encodable",
-        "Hashable",
-        "Equatable",
-        "_HasCustomAnyHashableRepresentation",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "IntegerLiteralType",
           "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Su18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -61768,19 +69175,15 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Su18IntegerLiteralTypea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Su10bitPatternSuSi_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61794,25 +69197,57 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Su10bitPatternSuSi_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SuySuSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
+              "name": "Optional",
+              "printedName": "UInt?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -61820,85 +69255,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:Su7exactlySuSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UInt?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UInt",
-                  "printedName": "UInt",
-                  "usr": "s:Su"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SuySuSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt",
-              "printedName": "UInt",
-              "usr": "s:Su"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Su7exactlySuSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61906,7 +69304,8 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -61914,19 +69313,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Su7exactlySuSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SuySus7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -61940,25 +69338,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SuySus7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Su7exactlySuSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UInt?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -61966,7 +69362,8 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -61974,19 +69371,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Su7exactlySuSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2eeoiySbSu_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1loiySbSu_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2peoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2seoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2meoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2deoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:Su24dividedReportingOverflow2bySu12partialValue_Sb8overflowtSu_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62013,19 +69597,18 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su24dividedReportingOverflow2bySu12partialValue_Sb8overflowtSu_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:Su26remainderReportingOverflow10dividingBySu12partialValue_Sb8overflowtSu_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62052,19 +69635,18 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su26remainderReportingOverflow10dividingBySu12partialValue_Sb8overflowtSu_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:Su23addingReportingOverflowySu12partialValue_Sb8overflowtSuF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62091,19 +69673,18 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su23addingReportingOverflowySu12partialValue_Sb8overflowtSuF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:Su28subtractingReportingOverflowySu12partialValue_Sb8overflowtSuF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62130,19 +69711,18 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su28subtractingReportingOverflowySu12partialValue_Sb8overflowtSuF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:Su27multipliedReportingOverflow2bySu12partialValue_Sb8overflowtSu_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62169,20 +69749,204 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su27multipliedReportingOverflow2bySu12partialValue_Sb8overflowtSu_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2reoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2aeoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2oeoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2xeoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su4aggeoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su4alleoiyySuz_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:Su8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62194,11 +69958,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62206,21 +69965,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Su8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:Su19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62232,10 +69995,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62243,21 +70002,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Su19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:Su20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62269,10 +70030,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62280,21 +70037,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Su20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:Su15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62306,10 +70065,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62317,41 +70072,33 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Su15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:Su5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Indices",
               "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:Su5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<Int>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -62359,24 +70106,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Su5WordsV7Indicesa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:Su5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Slice",
                   "printedName": "Slice<UInt.Words>",
-                  "usr": "s:s5SliceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -62384,21 +70130,18 @@
                       "printedName": "UInt.Words",
                       "usr": "s:Su5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s5SliceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Su5WordsV11SubSequencea",
+              "moduleName": "Swift"
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:Su5WordsVyABSucfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62412,19 +70155,18 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:Su5WordsVyABSucfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:Su5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62436,10 +70178,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Su5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -62447,21 +70185,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Su5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Su5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:Su5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62473,10 +70213,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Su5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -62484,21 +70220,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Su5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Su5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:Su5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62510,10 +70248,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Su5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -62521,21 +70255,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Su5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Su5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:Su5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -62546,7 +70282,6 @@
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -62554,7 +70289,8 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
                   ]
                 },
@@ -62562,10 +70298,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Su5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -62576,7 +70308,6 @@
                           "kind": "TypeNominal",
                           "name": "Range",
                           "printedName": "Range<Int>",
-                          "usr": "s:Sn",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -62584,25 +70315,28 @@
                               "printedName": "Int",
                               "usr": "s:Si"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sn"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Su5WordsV7indicesSnySiGvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Su5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:Su5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62616,19 +70350,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Su5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:Su5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62642,16 +70375,43 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Su5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:Su5WordsVySuSicip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:Su5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62659,16 +70419,16 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Su5WordsV7Elementa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Index",
               "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:Su5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62676,22 +70436,21 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Su5WordsV5Indexa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:Su5WordsV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "IndexingIterator",
                   "printedName": "IndexingIterator<UInt.Words>",
-                  "usr": "s:s16IndexingIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -62699,23 +70458,33 @@
                       "printedName": "UInt.Words",
                       "usr": "s:Su5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s16IndexingIteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Su5WordsV8Iteratora",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:Su5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:Su5wordsSu5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62727,10 +70496,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su5wordsSu5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62738,18 +70503,23 @@
                   "printedName": "UInt.Words",
                   "usr": "s:Su5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su5wordsSu5WordsVvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Su5wordsSu5WordsVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Magnitude",
           "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:Su9Magnitudea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -62757,19 +70527,15 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Su9Magnitudea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:Su19multipliedFullWidth2bySu4high_Su3lowtSu_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62803,19 +70569,18 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su19multipliedFullWidth2bySu4high_Su3lowtSu_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:Su17dividingFullWidthySu8quotient_Su9remaindertSu4high_Su3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62862,19 +70627,18 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su17dividingFullWidthySu8quotient_Su9remaindertSu4high_Su3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:Su11byteSwappedSuvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62886,10 +70650,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su11byteSwappedSuvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -62897,43 +70657,23 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su11byteSwappedSuvg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "toIntMax",
-          "printedName": "toIntMax()",
-          "declKind": "Func",
-          "usr": "s:Su8toIntMaxs5Int64VyF",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:Su11byteSwappedSuvp",
           "moduleName": "Swift",
           "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
-            }
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:Su6signumSuyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62941,16 +70681,19 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su6signumSuyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:Su6Stridea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -62958,20 +70701,16 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Su6Stridea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:Su4fromSus7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -62985,20 +70724,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Su4fromSus7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:Su6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63011,19 +70746,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Su6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Su10bitPatternSus13OpaquePointerVSg_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63035,7 +70767,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "OpaquePointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63043,21 +70774,21 @@
                   "printedName": "OpaquePointer",
                   "usr": "s:s13OpaquePointerV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Su10bitPatternSus13OpaquePointerVSg_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:Su4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63070,16 +70801,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Su9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -63091,10 +70824,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63102,23 +70831,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Su9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Su20truncatingBitPatternSus6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -63128,25 +70856,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1aoiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Su20truncatingBitPatternSus5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -63156,20 +70888,381 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1ooiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1xoiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su3aggoiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su3alloiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1doiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1roiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1poiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1soiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1moiyS2u_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2leoiySbSu_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su2geoiySbSu_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UInt",
+              "printedName": "UInt",
+              "usr": "s:Su"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Su1goiySbSu_SutFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Su12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -63181,10 +71274,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63192,23 +71281,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su12customMirrors0B0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Su12customMirrors0B0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:Su25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63220,10 +71306,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Su25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63231,21 +71313,24 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Su25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Su25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Su10bitPatternSuSO_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63259,20 +71344,18 @@
               "printedName": "ObjectIdentifier",
               "usr": "s:SO"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Su10bitPatternSuSO_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Su10bitPatternSuxSg_tcs8_PointerRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<P where P : _Pointer>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63284,61 +71367,61 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "P?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "P"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Su10bitPatternSuxSg_tcs8_PointerRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<P where P : _Pointer>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:Su",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Comparable",
+        "UnsignedInteger",
+        "_ExpressibleByBuiltinIntegerLiteral",
+        "BinaryInteger",
+        "LosslessStringConvertible",
+        "Numeric",
+        "CustomStringConvertible",
+        "Strideable",
+        "ExpressibleByIntegerLiteral",
+        "FixedWidthInteger",
+        "Encodable",
+        "Decodable",
+        "Hashable",
+        "Equatable",
+        "_HasCustomAnyHashableRepresentation",
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Int",
       "printedName": "Int",
-      "declKind": "Struct",
-      "usr": "s:Si",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Comparable",
-        "SignedInteger",
-        "_ExpressibleByBuiltinIntegerLiteral",
-        "BinaryInteger",
-        "LosslessStringConvertible",
-        "SignedNumeric",
-        "Numeric",
-        "CustomStringConvertible",
-        "Strideable",
-        "ExpressibleByIntegerLiteral",
-        "FixedWidthInteger",
-        "Decodable",
-        "Encodable",
-        "Hashable",
-        "Equatable",
-        "_HasCustomAnyHashableRepresentation",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "MirrorPath",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "IntegerLiteralType",
           "printedName": "IntegerLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Si18IntegerLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -63346,19 +71429,15 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Si18IntegerLiteralTypea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Si10bitPatternSiSu_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63372,25 +71451,57 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Si10bitPatternSiSu_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Float",
+              "printedName": "Float",
+              "usr": "s:Sf"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SiySiSfcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(exactly:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
+              "name": "Optional",
+              "printedName": "Int?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -63398,85 +71509,48 @@
               "printedName": "Float",
               "usr": "s:Sf"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(exactly:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:Si7exactlySiSgSf_tcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Int?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Float",
-              "printedName": "Float",
-              "usr": "s:Sf"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Double",
+              "printedName": "Double",
+              "usr": "s:Sd"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SiySiSdcfc",
-          "location": "",
           "moduleName": "Swift",
           "declAttributes": [
             "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Double",
-              "printedName": "Double",
-              "usr": "s:Sd"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Si7exactlySiSgSd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63484,7 +71558,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -63492,19 +71567,18 @@
               "printedName": "Double",
               "usr": "s:Sd"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Si7exactlySiSgSd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SiySis7Float80Vcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63518,25 +71592,23 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SiySis7Float80Vcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(exactly:)",
-          "declKind": "Constructor",
-          "usr": "s:Si7exactlySiSgs7Float80V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63544,7 +71616,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -63552,19 +71625,206 @@
               "printedName": "Float80",
               "usr": "s:s7Float80V"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Si7exactlySiSgs7Float80V_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2eeoiySbSi_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1loiySbSi_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2peoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2seoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*=",
+          "printedName": "*=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2meoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/=",
+          "printedName": "\/=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2deoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "dividedReportingOverflow",
           "printedName": "dividedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:Si24dividedReportingOverflow2bySi12partialValue_Sb8overflowtSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63591,19 +71851,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si24dividedReportingOverflow2bySi12partialValue_Sb8overflowtSi_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "remainderReportingOverflow",
           "printedName": "remainderReportingOverflow(dividingBy:)",
-          "declKind": "Func",
-          "usr": "s:Si26remainderReportingOverflow10dividingBySi12partialValue_Sb8overflowtSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63630,19 +71889,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si26remainderReportingOverflow10dividingBySi12partialValue_Sb8overflowtSi_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "addingReportingOverflow",
           "printedName": "addingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:Si23addingReportingOverflowySi12partialValue_Sb8overflowtSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63669,19 +71927,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si23addingReportingOverflowySi12partialValue_Sb8overflowtSiF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "subtractingReportingOverflow",
           "printedName": "subtractingReportingOverflow(_:)",
-          "declKind": "Func",
-          "usr": "s:Si28subtractingReportingOverflowySi12partialValue_Sb8overflowtSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63708,19 +71965,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si28subtractingReportingOverflowySi12partialValue_Sb8overflowtSiF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedReportingOverflow",
           "printedName": "multipliedReportingOverflow(by:)",
-          "declKind": "Func",
-          "usr": "s:Si27multipliedReportingOverflow2bySi12partialValue_Sb8overflowtSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63747,20 +72003,204 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si27multipliedReportingOverflow2bySi12partialValue_Sb8overflowtSi_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%=",
+          "printedName": "%=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2reoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&=",
+          "printedName": "&=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2aeoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "|=",
+          "printedName": "|=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2oeoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^=",
+          "printedName": "^=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2xeoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>=",
+          "printedName": "&>>=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si4aggeoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<=",
+          "printedName": "&<<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si4alleoiyySiz_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "bitWidth",
           "printedName": "bitWidth",
-          "declKind": "Var",
-          "usr": "s:Si8bitWidthSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63772,11 +72212,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si8bitWidthSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63784,21 +72219,25 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si8bitWidthSivgZ",
+              "moduleName": "Swift",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Si8bitWidthSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "leadingZeroBitCount",
           "printedName": "leadingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:Si19leadingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63810,10 +72249,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si19leadingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63821,21 +72256,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si19leadingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Si19leadingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "trailingZeroBitCount",
           "printedName": "trailingZeroBitCount",
-          "declKind": "Var",
-          "usr": "s:Si20trailingZeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63847,10 +72284,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si20trailingZeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63858,21 +72291,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si20trailingZeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Si20trailingZeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "nonzeroBitCount",
           "printedName": "nonzeroBitCount",
-          "declKind": "Var",
-          "usr": "s:Si15nonzeroBitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -63884,10 +72319,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si15nonzeroBitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63895,41 +72326,33 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si15nonzeroBitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Si15nonzeroBitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Words",
           "printedName": "Words",
-          "declKind": "Struct",
-          "usr": "s:Si5WordsV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Indices",
               "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:Si5WordsV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<Int>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -63937,24 +72360,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Si5WordsV7Indicesa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:Si5WordsV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Slice",
                   "printedName": "Slice<Int.Words>",
-                  "usr": "s:s5SliceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -63962,21 +72384,18 @@
                       "printedName": "Int.Words",
                       "usr": "s:Si5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s5SliceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Si5WordsV11SubSequencea",
+              "moduleName": "Swift"
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:Si5WordsVyABSicfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -63990,19 +72409,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:Si5WordsVyABSicfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:Si5WordsV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64014,10 +72432,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Si5WordsV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -64025,21 +72439,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Si5WordsV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Si5WordsV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:Si5WordsV10startIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64051,10 +72467,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Si5WordsV10startIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -64062,21 +72474,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Si5WordsV10startIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Si5WordsV10startIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:Si5WordsV8endIndexSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64088,10 +72502,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Si5WordsV8endIndexSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -64099,21 +72509,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Si5WordsV8endIndexSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Si5WordsV8endIndexSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:Si5WordsV7indicesSnySiGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -64124,7 +72536,6 @@
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -64132,7 +72543,8 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
                   ]
                 },
@@ -64140,10 +72552,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Si5WordsV7indicesSnySiGvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -64154,7 +72562,6 @@
                           "kind": "TypeNominal",
                           "name": "Range",
                           "printedName": "Range<Int>",
-                          "usr": "s:Sn",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -64162,25 +72569,28 @@
                               "printedName": "Int",
                               "usr": "s:Si"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sn"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Si5WordsV7indicesSnySiGvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Si5WordsV7indicesSnySiGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:Si5WordsV5index5afterS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64194,19 +72604,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Si5WordsV5index5afterS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:Si5WordsV5index6beforeS2i_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64220,16 +72629,43 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Si5WordsV5index6beforeS2i_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt",
+                  "printedName": "UInt",
+                  "usr": "s:Su"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:Si5WordsVySuSicip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:Si5WordsV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64237,16 +72673,16 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Si5WordsV7Elementa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Index",
               "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:Si5WordsV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64254,22 +72690,21 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Si5WordsV5Indexa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:Si5WordsV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "IndexingIterator",
                   "printedName": "IndexingIterator<Int.Words>",
-                  "usr": "s:s16IndexingIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -64277,23 +72712,33 @@
                       "printedName": "Int.Words",
                       "usr": "s:Si5WordsV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s16IndexingIteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Si5WordsV8Iteratora",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:Si5WordsV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "RandomAccessCollection",
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "words",
           "printedName": "words",
-          "declKind": "Var",
-          "usr": "s:Si5wordsSi5WordsVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64305,10 +72750,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si5wordsSi5WordsVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64316,18 +72757,23 @@
                   "printedName": "Int.Words",
                   "usr": "s:Si5WordsV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si5wordsSi5WordsVvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Si5wordsSi5WordsVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Magnitude",
           "printedName": "Magnitude",
-          "declKind": "TypeAlias",
-          "usr": "s:Si9Magnitudea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -64335,19 +72781,15 @@
               "printedName": "UInt",
               "usr": "s:Su"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Si9Magnitudea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "magnitude",
           "printedName": "magnitude",
-          "declKind": "Var",
-          "usr": "s:Si9magnitudeSuvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64359,10 +72801,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si9magnitudeSuvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64370,21 +72808,23 @@
                   "printedName": "UInt",
                   "usr": "s:Su"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si9magnitudeSuvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Si9magnitudeSuvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "multipliedFullWidth",
           "printedName": "multipliedFullWidth(by:)",
-          "declKind": "Func",
-          "usr": "s:Si19multipliedFullWidth2bySi4high_Su3lowtSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64418,19 +72858,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si19multipliedFullWidth2bySi4high_Su3lowtSi_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dividingFullWidth",
           "printedName": "dividingFullWidth(_:)",
-          "declKind": "Func",
-          "usr": "s:Si17dividingFullWidthySi8quotient_Si9remaindertSi4high_Su3lowt_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64477,19 +72916,18 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si17dividingFullWidthySi8quotient_Si9remaindertSi4high_Su3lowt_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "byteSwapped",
           "printedName": "byteSwapped",
-          "declKind": "Var",
-          "usr": "s:Si11byteSwappedSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64501,10 +72939,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si11byteSwappedSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64512,43 +72946,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si11byteSwappedSivg",
+              "moduleName": "Swift"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "toUIntMax",
-          "printedName": "toUIntMax()",
-          "declKind": "Func",
-          "usr": "s:Si9toUIntMaxs6UInt64VyF",
-          "location": "",
+          ],
+          "declKind": "Var",
+          "usr": "s:Si11byteSwappedSivp",
           "moduleName": "Swift",
           "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
-            }
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "signum",
           "printedName": "signum()",
-          "declKind": "Func",
-          "usr": "s:Si6signumSiyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64556,16 +72970,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si6signumSiyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:Si6Stridea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -64573,20 +72990,16 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Si6Stridea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:Si4fromSis7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64600,20 +73013,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Si4fromSis7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:Si6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64626,19 +73035,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Si6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Si10bitPatternSis13OpaquePointerVSg_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64650,7 +73056,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "OpaquePointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64658,73 +73063,21 @@
                   "printedName": "OpaquePointer",
                   "usr": "s:s13OpaquePointerV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "distance",
-          "printedName": "distance(to:)",
-          "declKind": "Func",
-          "usr": "s:Si8distance2toS2i_tF",
-          "location": "",
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Si10bitPatternSis13OpaquePointerVSg_tcfc",
           "moduleName": "Swift",
           "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "advanced",
-          "printedName": "advanced(by:)",
-          "declKind": "Func",
-          "usr": "s:Si8advanced2byS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:Si4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64737,16 +73090,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Si9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -64758,10 +73113,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64769,23 +73120,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Si9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Si20truncatingBitPatternSis6UInt64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "&",
+          "printedName": "&(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -64795,25 +73145,29 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "UInt64",
-              "printedName": "UInt64",
-              "usr": "s:s6UInt64V"
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1aoiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(truncatingBitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Si20truncatingBitPatternSis5Int64V_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Available",
-            "Inlinable"
-          ],
+          "kind": "Function",
+          "name": "|",
+          "printedName": "|(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -64823,20 +73177,431 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "Int64",
-              "printedName": "Int64",
-              "usr": "s:s5Int64V"
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1ooiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "^",
+          "printedName": "^(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1xoiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&>>",
+          "printedName": "&>>(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si3aggoiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "&<<",
+          "printedName": "&<<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si3alloiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "\/",
+          "printedName": "\/(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1doiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "%",
+          "printedName": "%(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1roiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1poiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1soiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "*",
+          "printedName": "*(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1moiyS2i_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2leoiySbSi_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si2geoiySbSi_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si1goiySbSi_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "distance",
+          "printedName": "distance(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si8distance2toS2i_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "advanced",
+          "printedName": "advanced(by:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Si8advanced2byS2i_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Si12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -64848,10 +73613,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64859,23 +73620,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si12customMirrors0B0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Si12customMirrors0B0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:Si25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64887,10 +73645,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Si25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -64898,21 +73652,24 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Si25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Si25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Si10bitPatternSiSO_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64926,20 +73683,18 @@
               "printedName": "ObjectIdentifier",
               "usr": "s:SO"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Si10bitPatternSiSO_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bitPattern:)",
-          "declKind": "Constructor",
-          "usr": "s:Si10bitPatternSixSg_tcs8_PointerRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<P where P : _Pointer>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -64951,102 +73706,92 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "P?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "P"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Si10bitPatternSixSg_tcs8_PointerRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<P where P : _Pointer>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
-      ]
-    },
-    {
-      "kind": "Function",
-      "name": "numericCast",
-      "printedName": "numericCast(_:)",
-      "declKind": "Func",
-      "usr": "s:s11numericCastyq_xSzRzSzR_r0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, U where T : BinaryInteger, U : BinaryInteger>",
-      "declAttributes": [
-        "Transparent"
       ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "U"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        }
+      "declKind": "Struct",
+      "usr": "s:Si",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Comparable",
+        "SignedInteger",
+        "_ExpressibleByBuiltinIntegerLiteral",
+        "BinaryInteger",
+        "LosslessStringConvertible",
+        "SignedNumeric",
+        "Numeric",
+        "CustomStringConvertible",
+        "Strideable",
+        "ExpressibleByIntegerLiteral",
+        "FixedWidthInteger",
+        "Encodable",
+        "Decodable",
+        "Hashable",
+        "Equatable",
+        "_HasCustomAnyHashableRepresentation",
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "MirrorPath",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "JoinedSequence",
       "printedName": "JoinedSequence",
-      "declKind": "Struct",
-      "usr": "s:s14JoinedSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-      "conformingProtocols": [
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s14JoinedSequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Element.Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s14JoinedSequenceV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(base:separator:)",
-          "declKind": "Constructor",
-          "usr": "s:s14JoinedSequenceV4base9separatorAByxGx_qd__tcSTRd__7Element_AFQZAFRtd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Separator where Base : Sequence, Separator : Sequence, Base.Element : Sequence, Separator.Element == Base.Element.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "JoinedSequence",
               "printedName": "JoinedSequence<Base>",
-              "usr": "s:s14JoinedSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "usr": "s:s14JoinedSequenceV"
             },
             {
               "kind": "TypeNominal",
@@ -65058,36 +73803,24 @@
               "name": "GenericTypeParam",
               "printedName": "Separator"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s14JoinedSequenceV4base9separatorAByxGx_qd__tcSTRd__7Element_AFQZAFRtd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Separator where Base : Sequence, Separator : Sequence, Base.Element : Sequence, Separator.Element == Base.Element.Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s14JoinedSequenceV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-          "conformingProtocols": [
-            "IteratorProtocol"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(base:separator:)",
-              "declKind": "Constructor",
-              "usr": "s:s14JoinedSequenceV8IteratorV4base9separatorADyx_GACQz_qd__tcSTRd__7Element_AIQZAIRtd__lufc",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Separator where Base : Sequence, Separator : Sequence, Base.Element : Sequence, Separator.Element == Base.Element.Element>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65105,44 +73838,40 @@
                   "name": "GenericTypeParam",
                   "printedName": "Separator"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s14JoinedSequenceV8IteratorV4base9separatorADyx_GACQz_qd__tcSTRd__7Element_AIQZAIRtd__lufc",
+              "moduleName": "Swift",
+              "genericSig": "<Base, Separator where Base : Sequence, Separator : Sequence, Base.Element : Sequence, Separator.Element == Base.Element.Element>",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s14JoinedSequenceV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Element.Element"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s14JoinedSequenceV8IteratorV7Elementa",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>"
             },
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s14JoinedSequenceV8IteratorV4next7Element_AFQZSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "JoinedSequence<Base>.Iterator.Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -65156,24 +73885,35 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s14JoinedSequenceV8IteratorV4next7Element_AFQZSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s14JoinedSequenceV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s14JoinedSequenceV12makeIteratorAB0D0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -65181,62 +73921,61 @@
               "printedName": "JoinedSequence<Base>.Iterator",
               "usr": "s:s14JoinedSequenceV8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14JoinedSequenceV12makeIteratorAB0D0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s14JoinedSequenceV03SubB0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Base.Element.Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Element.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s14JoinedSequenceV03SubB0a",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s14JoinedSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<Base where Base : Sequence, Base.Element : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AnyKeyPath",
       "printedName": "AnyKeyPath",
-      "declKind": "Class",
-      "usr": "s:s10AnyKeyPathC",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Hashable",
-        "_AppendKeyPath",
-        "Equatable"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "rootType",
           "printedName": "rootType",
-          "declKind": "Var",
-          "usr": "s:s10AnyKeyPathC8rootTypeypXpvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Final",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -65254,14 +73993,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10AnyKeyPathC8rootTypeypXpvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Final"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65275,23 +74006,29 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10AnyKeyPathC8rootTypeypXpvgZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Final"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10AnyKeyPathC8rootTypeypXpvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Final",
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "valueType",
           "printedName": "valueType",
-          "declKind": "Var",
-          "usr": "s:s10AnyKeyPathC9valueTypeypXpvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Final",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -65309,14 +74046,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10AnyKeyPathC9valueTypeypXpvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Final"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65330,21 +74059,29 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10AnyKeyPathC9valueTypeypXpvgZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Final"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10AnyKeyPathC9valueTypeypXpvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Final",
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s10AnyKeyPathC9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Final"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -65356,13 +74093,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10AnyKeyPathC9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Final"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65370,22 +74100,26 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10AnyKeyPathC9hashValueSivg",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Final"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10AnyKeyPathC9hashValueSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Final"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s10AnyKeyPathC4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Final",
-            "Effects"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -65398,16 +74132,51 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10AnyKeyPathC4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Final",
+            "Effects"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyKeyPath",
+              "printedName": "AnyKeyPath",
+              "usr": "s:s10AnyKeyPathC"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyKeyPath",
+              "printedName": "AnyKeyPath",
+              "usr": "s:s10AnyKeyPathC"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10AnyKeyPathC2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Final"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s10AnyKeyPathCABycfc",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -65415,84 +74184,83 @@
               "printedName": "AnyKeyPath",
               "usr": "s:s10AnyKeyPathC"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s10AnyKeyPathCABycfc",
+          "moduleName": "Swift",
+          "isInternal": true
         }
+      ],
+      "declKind": "Class",
+      "usr": "s:s10AnyKeyPathC",
+      "moduleName": "Swift",
+      "conformingProtocols": [
+        "Hashable",
+        "_AppendKeyPath",
+        "Equatable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "PartialKeyPath",
       "printedName": "PartialKeyPath",
-      "declKind": "Class",
-      "usr": "s:s14PartialKeyPathC",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Root>",
-      "superclassUsr": "s:s10AnyKeyPathC",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable",
-        "_AppendKeyPath"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s14PartialKeyPathCAByxGycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Root>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "PartialKeyPath",
               "printedName": "PartialKeyPath<Root>",
-              "usr": "s:s14PartialKeyPathC",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Root"
                 }
-              ]
+              ],
+              "usr": "s:s14PartialKeyPathC"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s14PartialKeyPathCAByxGycfc",
+          "moduleName": "Swift",
+          "genericSig": "<Root>",
+          "overriding": true,
+          "implicit": true,
+          "isInternal": true
         }
+      ],
+      "declKind": "Class",
+      "usr": "s:s14PartialKeyPathC",
+      "moduleName": "Swift",
+      "genericSig": "<Root>",
+      "superclassUsr": "s:s10AnyKeyPathC",
+      "superclassNames": [
+        "AnyKeyPath"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable",
+        "_AppendKeyPath"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "KeyPath",
       "printedName": "KeyPath",
-      "declKind": "Class",
-      "usr": "s:s7KeyPathC",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Root, Value>",
-      "superclassUsr": "s:s14PartialKeyPathC",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable",
-        "_AppendKeyPath"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s7KeyPathCAByxq_Gycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Root, Value>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyPath",
               "printedName": "KeyPath<Root, Value>",
-              "usr": "s:s7KeyPathC",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65504,43 +74272,48 @@
                   "name": "GenericTypeParam",
                   "printedName": "Value"
                 }
-              ]
+              ],
+              "usr": "s:s7KeyPathC"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s7KeyPathCAByxq_Gycfc",
+          "moduleName": "Swift",
+          "genericSig": "<Root, Value>",
+          "overriding": true,
+          "implicit": true,
+          "isInternal": true
         }
+      ],
+      "declKind": "Class",
+      "usr": "s:s7KeyPathC",
+      "moduleName": "Swift",
+      "genericSig": "<Root, Value>",
+      "superclassUsr": "s:s14PartialKeyPathC",
+      "superclassNames": [
+        "PartialKeyPath<τ_0_0>",
+        "AnyKeyPath"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable",
+        "_AppendKeyPath"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "WritableKeyPath",
       "printedName": "WritableKeyPath",
-      "declKind": "Class",
-      "usr": "s:s15WritableKeyPathC",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Root, Value>",
-      "superclassUsr": "s:s7KeyPathC",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable",
-        "_AppendKeyPath"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s15WritableKeyPathCAByxq_Gycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Root, Value>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "WritableKeyPath",
               "printedName": "WritableKeyPath<Root, Value>",
-              "usr": "s:s15WritableKeyPathC",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65552,43 +74325,49 @@
                   "name": "GenericTypeParam",
                   "printedName": "Value"
                 }
-              ]
+              ],
+              "usr": "s:s15WritableKeyPathC"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s15WritableKeyPathCAByxq_Gycfc",
+          "moduleName": "Swift",
+          "genericSig": "<Root, Value>",
+          "overriding": true,
+          "implicit": true,
+          "isInternal": true
         }
+      ],
+      "declKind": "Class",
+      "usr": "s:s15WritableKeyPathC",
+      "moduleName": "Swift",
+      "genericSig": "<Root, Value>",
+      "superclassUsr": "s:s7KeyPathC",
+      "superclassNames": [
+        "KeyPath<τ_0_0, τ_0_1>",
+        "PartialKeyPath<τ_0_0>",
+        "AnyKeyPath"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable",
+        "_AppendKeyPath"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "ReferenceWritableKeyPath",
       "printedName": "ReferenceWritableKeyPath",
-      "declKind": "Class",
-      "usr": "s:s24ReferenceWritableKeyPathC",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Root, Value>",
-      "superclassUsr": "s:s15WritableKeyPathC",
-      "conformingProtocols": [
-        "Equatable",
-        "Hashable",
-        "_AppendKeyPath"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s24ReferenceWritableKeyPathCAByxq_Gycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Root, Value>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ReferenceWritableKeyPath",
               "printedName": "ReferenceWritableKeyPath<Root, Value>",
-              "usr": "s:s24ReferenceWritableKeyPathC",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65600,42 +74379,50 @@
                   "name": "GenericTypeParam",
                   "printedName": "Value"
                 }
-              ]
+              ],
+              "usr": "s:s24ReferenceWritableKeyPathC"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s24ReferenceWritableKeyPathCAByxq_Gycfc",
+          "moduleName": "Swift",
+          "genericSig": "<Root, Value>",
+          "overriding": true,
+          "implicit": true,
+          "isInternal": true
         }
+      ],
+      "declKind": "Class",
+      "usr": "s:s24ReferenceWritableKeyPathC",
+      "moduleName": "Swift",
+      "genericSig": "<Root, Value>",
+      "superclassUsr": "s:s15WritableKeyPathC",
+      "superclassNames": [
+        "WritableKeyPath<τ_0_0, τ_0_1>",
+        "KeyPath<τ_0_0, τ_0_1>",
+        "PartialKeyPath<τ_0_0>",
+        "AnyKeyPath"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Hashable",
+        "_AppendKeyPath"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "_AppendKeyPath",
       "printedName": "_AppendKeyPath",
-      "declKind": "Protocol",
-      "usr": "s:s14_AppendKeyPathP",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "ShowInInterface"
-      ],
       "children": [
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
-          "declKind": "Func",
-          "usr": "s:s14_AppendKeyPathPss03AnybC0CRszrlE9appending4pathADSgAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self == AnyKeyPath>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "AnyKeyPath?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65643,7 +74430,8 @@
                   "printedName": "AnyKeyPath",
                   "usr": "s:s10AnyKeyPathC"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -65651,41 +74439,40 @@
               "printedName": "AnyKeyPath",
               "usr": "s:s10AnyKeyPathC"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14_AppendKeyPathPss03AnybC0CRszrlE9appending4pathADSgAD_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self == AnyKeyPath>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
-          "declKind": "Func",
-          "usr": "s:s14_AppendKeyPathPsE9appending4paths07PartialbC0Cyqd__GSgs03AnybC0C_tAGRszlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Root where Self == PartialKeyPath<Root>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "PartialKeyPath<Root>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "PartialKeyPath",
                   "printedName": "PartialKeyPath<Root>",
-                  "usr": "s:s14PartialKeyPathC",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Root"
                     }
-                  ]
+                  ],
+                  "usr": "s:s14PartialKeyPathC"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -65693,32 +74480,29 @@
               "printedName": "AnyKeyPath",
               "usr": "s:s10AnyKeyPathC"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14_AppendKeyPathPsE9appending4paths07PartialbC0Cyqd__GSgs03AnybC0C_tAGRszlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Root where Self == PartialKeyPath<Root>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
-          "declKind": "Func",
-          "usr": "s:s14_AppendKeyPathPsE9appending4paths0bC0Cyqd__qd_1_GSgAFyqd_0_qd_1_G_ts07PartialbC0Cyqd__GRszr1_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Root, AppendedRoot, AppendedValue where Self == PartialKeyPath<Root>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "KeyPath<Root, AppendedValue>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "KeyPath",
                   "printedName": "KeyPath<Root, AppendedValue>",
-                  "usr": "s:s7KeyPathC",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -65730,15 +74514,16 @@
                       "name": "GenericTypeParam",
                       "printedName": "AppendedValue"
                     }
-                  ]
+                  ],
+                  "usr": "s:s7KeyPathC"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "KeyPath",
               "printedName": "KeyPath<AppendedRoot, AppendedValue>",
-              "usr": "s:s7KeyPathC",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65750,34 +74535,32 @@
                   "name": "GenericTypeParam",
                   "printedName": "AppendedValue"
                 }
-              ]
+              ],
+              "usr": "s:s7KeyPathC"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14_AppendKeyPathPsE9appending4paths0bC0Cyqd__qd_1_GSgAFyqd_0_qd_1_G_ts07PartialbC0Cyqd__GRszr1_lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Root, AppendedRoot, AppendedValue where Self == PartialKeyPath<Root>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
-          "declKind": "Func",
-          "usr": "s:s14_AppendKeyPathPsE9appending4paths017ReferenceWritablebC0Cyqd__qd_1_GSgAFyqd_0_qd_1_G_ts07PartialbC0Cyqd__GRszr1_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Root, AppendedRoot, AppendedValue where Self == PartialKeyPath<Root>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "ReferenceWritableKeyPath<Root, AppendedValue>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ReferenceWritableKeyPath",
                   "printedName": "ReferenceWritableKeyPath<Root, AppendedValue>",
-                  "usr": "s:s24ReferenceWritableKeyPathC",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -65789,15 +74572,16 @@
                       "name": "GenericTypeParam",
                       "printedName": "AppendedValue"
                     }
-                  ]
+                  ],
+                  "usr": "s:s24ReferenceWritableKeyPathC"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "ReferenceWritableKeyPath",
               "printedName": "ReferenceWritableKeyPath<AppendedRoot, AppendedValue>",
-              "usr": "s:s24ReferenceWritableKeyPathC",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65809,28 +74593,27 @@
                   "name": "GenericTypeParam",
                   "printedName": "AppendedValue"
                 }
-              ]
+              ],
+              "usr": "s:s24ReferenceWritableKeyPathC"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14_AppendKeyPathPsE9appending4paths017ReferenceWritablebC0Cyqd__qd_1_GSgAFyqd_0_qd_1_G_ts07PartialbC0Cyqd__GRszr1_lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Root, AppendedRoot, AppendedValue where Self == PartialKeyPath<Root>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
-          "declKind": "Func",
-          "usr": "s:s14_AppendKeyPathPsE9appending4paths0bC0Cyqd__qd_1_GAFyqd_0_qd_1_G_tAFyqd__qd_0_GRbzr1_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Root, Value, AppendedValue where Self : KeyPath<Root, Value>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "KeyPath",
               "printedName": "KeyPath<Root, AppendedValue>",
-              "usr": "s:s7KeyPathC",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65842,13 +74625,13 @@
                   "name": "GenericTypeParam",
                   "printedName": "AppendedValue"
                 }
-              ]
+              ],
+              "usr": "s:s7KeyPathC"
             },
             {
               "kind": "TypeNominal",
               "name": "KeyPath",
               "printedName": "KeyPath<Value, AppendedValue>",
-              "usr": "s:s7KeyPathC",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65860,28 +74643,27 @@
                   "name": "GenericTypeParam",
                   "printedName": "AppendedValue"
                 }
-              ]
+              ],
+              "usr": "s:s7KeyPathC"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14_AppendKeyPathPsE9appending4paths0bC0Cyqd__qd_1_GAFyqd_0_qd_1_G_tAFyqd__qd_0_GRbzr1_lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Root, Value, AppendedValue where Self : KeyPath<Root, Value>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
-          "declKind": "Func",
-          "usr": "s:s14_AppendKeyPathPsE9appending4paths017ReferenceWritablebC0Cyqd__qd_1_GAFyqd_0_qd_1_G_ts0bC0Cyqd__qd_0_GRszr1_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Root, Value, AppendedValue where Self == KeyPath<Root, Value>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ReferenceWritableKeyPath",
               "printedName": "ReferenceWritableKeyPath<Root, AppendedValue>",
-              "usr": "s:s24ReferenceWritableKeyPathC",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65893,13 +74675,13 @@
                   "name": "GenericTypeParam",
                   "printedName": "AppendedValue"
                 }
-              ]
+              ],
+              "usr": "s:s24ReferenceWritableKeyPathC"
             },
             {
               "kind": "TypeNominal",
               "name": "ReferenceWritableKeyPath",
               "printedName": "ReferenceWritableKeyPath<Value, AppendedValue>",
-              "usr": "s:s24ReferenceWritableKeyPathC",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65911,28 +74693,27 @@
                   "name": "GenericTypeParam",
                   "printedName": "AppendedValue"
                 }
-              ]
+              ],
+              "usr": "s:s24ReferenceWritableKeyPathC"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14_AppendKeyPathPsE9appending4paths017ReferenceWritablebC0Cyqd__qd_1_GAFyqd_0_qd_1_G_ts0bC0Cyqd__qd_0_GRszr1_lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Root, Value, AppendedValue where Self == KeyPath<Root, Value>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
-          "declKind": "Func",
-          "usr": "s:s14_AppendKeyPathPsE9appending4paths08WritablebC0Cyqd__qd_1_GAFyqd_0_qd_1_G_tAFyqd__qd_0_GRszr1_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Root, Value, AppendedValue where Self == WritableKeyPath<Root, Value>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "WritableKeyPath",
               "printedName": "WritableKeyPath<Root, AppendedValue>",
-              "usr": "s:s15WritableKeyPathC",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65944,13 +74725,13 @@
                   "name": "GenericTypeParam",
                   "printedName": "AppendedValue"
                 }
-              ]
+              ],
+              "usr": "s:s15WritableKeyPathC"
             },
             {
               "kind": "TypeNominal",
               "name": "WritableKeyPath",
               "printedName": "WritableKeyPath<Value, AppendedValue>",
-              "usr": "s:s15WritableKeyPathC",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65962,28 +74743,27 @@
                   "name": "GenericTypeParam",
                   "printedName": "AppendedValue"
                 }
-              ]
+              ],
+              "usr": "s:s15WritableKeyPathC"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14_AppendKeyPathPsE9appending4paths08WritablebC0Cyqd__qd_1_GAFyqd_0_qd_1_G_tAFyqd__qd_0_GRszr1_lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Root, Value, AppendedValue where Self == WritableKeyPath<Root, Value>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
-          "declKind": "Func",
-          "usr": "s:s14_AppendKeyPathPsE9appending4paths017ReferenceWritablebC0Cyqd__qd_1_GAFyqd_0_qd_1_G_ts0gbC0Cyqd__qd_0_GRszr1_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Root, Value, AppendedValue where Self == WritableKeyPath<Root, Value>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ReferenceWritableKeyPath",
               "printedName": "ReferenceWritableKeyPath<Root, AppendedValue>",
-              "usr": "s:s24ReferenceWritableKeyPathC",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -65995,13 +74775,13 @@
                   "name": "GenericTypeParam",
                   "printedName": "AppendedValue"
                 }
-              ]
+              ],
+              "usr": "s:s24ReferenceWritableKeyPathC"
             },
             {
               "kind": "TypeNominal",
               "name": "ReferenceWritableKeyPath",
               "printedName": "ReferenceWritableKeyPath<Value, AppendedValue>",
-              "usr": "s:s24ReferenceWritableKeyPathC",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -66013,28 +74793,27 @@
                   "name": "GenericTypeParam",
                   "printedName": "AppendedValue"
                 }
-              ]
+              ],
+              "usr": "s:s24ReferenceWritableKeyPathC"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14_AppendKeyPathPsE9appending4paths017ReferenceWritablebC0Cyqd__qd_1_GAFyqd_0_qd_1_G_ts0gbC0Cyqd__qd_0_GRszr1_lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Root, Value, AppendedValue where Self == WritableKeyPath<Root, Value>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "appending",
           "printedName": "appending(path:)",
-          "declKind": "Func",
-          "usr": "s:s14_AppendKeyPathPsE9appending4paths017ReferenceWritablebC0Cyqd__qd_1_Gs0gbC0Cyqd_0_qd_1_G_tAFyqd__qd_0_GRszr1_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Root, Value, AppendedValue where Self == ReferenceWritableKeyPath<Root, Value>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ReferenceWritableKeyPath",
               "printedName": "ReferenceWritableKeyPath<Root, AppendedValue>",
-              "usr": "s:s24ReferenceWritableKeyPathC",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -66046,13 +74825,13 @@
                   "name": "GenericTypeParam",
                   "printedName": "AppendedValue"
                 }
-              ]
+              ],
+              "usr": "s:s24ReferenceWritableKeyPathC"
             },
             {
               "kind": "TypeNominal",
               "name": "WritableKeyPath",
               "printedName": "WritableKeyPath<Value, AppendedValue>",
-              "usr": "s:s15WritableKeyPathC",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -66064,52 +74843,541 @@
                   "name": "GenericTypeParam",
                   "printedName": "AppendedValue"
                 }
-              ]
+              ],
+              "usr": "s:s15WritableKeyPathC"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14_AppendKeyPathPsE9appending4paths017ReferenceWritablebC0Cyqd__qd_1_Gs0gbC0Cyqd_0_qd_1_G_tAFyqd__qd_0_GRszr1_lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Root, Value, AppendedValue where Self == ReferenceWritableKeyPath<Root, Value>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s14_AppendKeyPathP",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "ShowInInterface"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "KeyValuePairs",
+      "printedName": "KeyValuePairs",
+      "children": [
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(dictionaryLiteral:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "KeyValuePairs",
+              "printedName": "KeyValuePairs<Key, Value>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Key"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Value"
+                }
+              ],
+              "usr": "s:s13KeyValuePairsV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Array",
+              "printedName": "[(Key, Value)]",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(Key, Value)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Key"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Value"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sa"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13KeyValuePairsV17dictionaryLiteralAByxq_Gx_q_td_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "Key",
+          "printedName": "Key",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Key"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s13KeyValuePairsV0A0a",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value>",
+          "implicit": true
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "Value",
+          "printedName": "Value",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Value"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s13KeyValuePairsV0B0a",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value>",
+          "implicit": true
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "Element",
+          "printedName": "Element",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Tuple",
+              "printedName": "(key: Key, value: Value)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Key"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Value"
+                }
+              ]
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s13KeyValuePairsV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value>"
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "Index",
+          "printedName": "Index",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s13KeyValuePairsV5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value>"
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "Indices",
+          "printedName": "Indices",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s13KeyValuePairsV7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value>"
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<KeyValuePairs<Key, Value>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "KeyValuePairs",
+                  "printedName": "KeyValuePairs<Key, Value>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Key"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Value"
+                    }
+                  ],
+                  "usr": "s:s13KeyValuePairsV"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s13KeyValuePairsV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value>"
+        },
+        {
+          "kind": "Var",
+          "name": "startIndex",
+          "printedName": "startIndex",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "KeyValuePairs<Key, Value>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ]
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "KeyValuePairs<Key, Value>.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ]
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13KeyValuePairsV10startIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13KeyValuePairsV10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Var",
+          "name": "endIndex",
+          "printedName": "endIndex",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "KeyValuePairs<Key, Value>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ]
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "KeyValuePairs<Key, Value>.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ]
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13KeyValuePairsV8endIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13KeyValuePairsV8endIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Element",
+              "printedName": "KeyValuePairs<Key, Value>.Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Tuple",
+                  "printedName": "(key: τ_0_0, value: τ_0_1)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ]
+                }
+              ]
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "KeyValuePairs<Key, Value>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ]
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s13KeyValuePairsVyx3key_q_5valuetSicip",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "Iterator",
+          "printedName": "Iterator",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "IndexingIterator",
+              "printedName": "IndexingIterator<KeyValuePairs<Key, Value>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "KeyValuePairs",
+                  "printedName": "KeyValuePairs<Key, Value>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Key"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Value"
+                    }
+                  ],
+                  "usr": "s:s13KeyValuePairsV"
+                }
+              ],
+              "usr": "s:s16IndexingIteratorV"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s13KeyValuePairsV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Key, Value>",
+          "implicit": true
+        },
+        {
+          "kind": "Var",
+          "name": "description",
+          "printedName": "description",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13KeyValuePairsV11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13KeyValuePairsV11descriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Var",
+          "name": "debugDescription",
+          "printedName": "debugDescription",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "String",
+                  "printedName": "String",
+                  "usr": "s:SS"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13KeyValuePairsV16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Key, Value>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13KeyValuePairsV16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s13KeyValuePairsV",
+      "moduleName": "Swift",
+      "genericSig": "<Key, Value>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "ExpressibleByDictionaryLiteral",
+        "RandomAccessCollection",
+        "BidirectionalCollection",
+        "Collection",
+        "Sequence",
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "LazyCollectionProtocol",
       "printedName": "LazyCollectionProtocol",
-      "declKind": "Protocol",
-      "usr": "s:s22LazyCollectionProtocolP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Collection, Self : LazySequenceProtocol, Self.Elements : Collection>",
-      "conformingProtocols": [
-        "Collection",
-        "LazySequenceProtocol",
-        "Sequence"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Elements",
+          "printedName": "Elements",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:s22LazyCollectionProtocolP8ElementsQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsE4drop5whiles0a9DropWhileB0Vy8ElementsQzGSb7ElementQzc_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LazyCollectionProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyDropWhileCollection",
               "printedName": "LazyDropWhileCollection<Self.Elements>",
-              "usr": "s:s23LazyDropWhileCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Elements"
                 }
-              ]
+              ],
+              "usr": "s:s23LazyDropWhileCollectionV"
             },
             {
               "kind": "TypeFunc",
@@ -66136,33 +75404,32 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsE4drop5whiles0a9DropWhileB0Vy8ElementsQzGSb7ElementQzc_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : LazyCollectionProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsE6filterys0a6FilterB0Vy8ElementsQzGSb7ElementQzcF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LazyCollectionProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyFilterCollection",
               "printedName": "LazyFilterCollection<Self.Elements>",
-              "usr": "s:s20LazyFilterCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Elements"
                 }
-              ]
+              ],
+              "usr": "s:s20LazyFilterCollectionV"
             },
             {
               "kind": "TypeFunc",
@@ -66189,38 +75456,34 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsE6filterys0a6FilterB0Vy8ElementsQzGSb7ElementQzcF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : LazyCollectionProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "flatMap",
           "printedName": "flatMap(_:)",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsE7flatMapys0aB0Vys07FlattenB0Vys0aeB0Vy8ElementsQzqd__GGGqd__7ElementQzcSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, SegmentOfResult where Self : LazyCollectionProtocol, SegmentOfResult : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyCollection",
               "printedName": "LazyCollection<FlattenCollection<LazyMapCollection<Self.Elements, SegmentOfResult>>>",
-              "usr": "s:s14LazyCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "FlattenCollection",
                   "printedName": "FlattenCollection<LazyMapCollection<Self.Elements, SegmentOfResult>>",
-                  "usr": "s:s17FlattenCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "LazyMapCollection",
                       "printedName": "LazyMapCollection<Self.Elements, SegmentOfResult>",
-                      "usr": "s:s17LazyMapCollectionV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -66232,11 +75495,14 @@
                           "name": "GenericTypeParam",
                           "printedName": "SegmentOfResult"
                         }
-                      ]
+                      ],
+                      "usr": "s:s17LazyMapCollectionV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s17FlattenCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:s14LazyCollectionV"
             },
             {
               "kind": "TypeFunc",
@@ -66262,38 +75528,34 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsE7flatMapys0aB0Vys07FlattenB0Vys0aeB0Vy8ElementsQzqd__GGGqd__7ElementQzcSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, SegmentOfResult where Self : LazyCollectionProtocol, SegmentOfResult : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "compactMap",
           "printedName": "compactMap(_:)",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsE10compactMapys0aeB0Vys0a6FilterB0VyAEy8ElementsQzqd__SgGGqd__GAJ7ElementQzclF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, ElementOfResult where Self : LazyCollectionProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyMapCollection",
               "printedName": "LazyMapCollection<LazyFilterCollection<LazyMapCollection<Self.Elements, ElementOfResult?>>, ElementOfResult>",
-              "usr": "s:s17LazyMapCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "LazyFilterCollection",
                   "printedName": "LazyFilterCollection<LazyMapCollection<Self.Elements, ElementOfResult?>>",
-                  "usr": "s:s20LazyFilterCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "LazyMapCollection",
                       "printedName": "LazyMapCollection<Self.Elements, ElementOfResult?>",
-                      "usr": "s:s17LazyMapCollectionV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -66304,25 +75566,28 @@
                           "kind": "TypeNominal",
                           "name": "Optional",
                           "printedName": "ElementOfResult?",
-                          "usr": "s:Sq",
                           "children": [
                             {
                               "kind": "TypeNominal",
                               "name": "GenericTypeParam",
                               "printedName": "ElementOfResult"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         }
-                      ]
+                      ],
+                      "usr": "s:s17LazyMapCollectionV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s20LazyFilterCollectionV"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "ElementOfResult"
                 }
-              ]
+              ],
+              "usr": "s:s17LazyMapCollectionV"
             },
             {
               "kind": "TypeFunc",
@@ -66333,14 +75598,14 @@
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "ElementOfResult?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "ElementOfResult"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -66356,107 +75621,104 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsE10compactMapys0aeB0Vys0a6FilterB0VyAEy8ElementsQzqd__SgGGqd__GAJ7ElementQzclF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, ElementOfResult where Self : LazyCollectionProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "joined",
           "printedName": "joined()",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsSl7ElementRpzrlE6joineds0aB0Vys07FlattenB0Vy8ElementsQzGGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LazyCollectionProtocol, Self.Element : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyCollection",
               "printedName": "LazyCollection<FlattenCollection<Self.Elements>>",
-              "usr": "s:s14LazyCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "FlattenCollection",
                   "printedName": "FlattenCollection<Self.Elements>",
-                  "usr": "s:s17FlattenCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Self.Elements"
                     }
-                  ]
+                  ],
+                  "usr": "s:s17FlattenCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:s14LazyCollectionV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsSl7ElementRpzrlE6joineds0aB0Vys07FlattenB0Vy8ElementsQzGGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : LazyCollectionProtocol, Self.Element : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "lazy",
           "printedName": "lazy",
-          "declKind": "Var",
-          "usr": "s:s22LazyCollectionProtocolPsE4lazys0aB0Vy8ElementsQzGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyCollection",
               "printedName": "LazyCollection<Self.Elements>",
-              "usr": "s:s14LazyCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Elements"
                 }
-              ]
+              ],
+              "usr": "s:s14LazyCollectionV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s22LazyCollectionProtocolPsE4lazys0aB0Vy8ElementsQzGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : LazyCollectionProtocol>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "LazyCollection",
                   "printedName": "LazyCollection<Self.Elements>",
-                  "usr": "s:s14LazyCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Self.Elements"
                     }
-                  ]
+                  ],
+                  "usr": "s:s14LazyCollectionV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s22LazyCollectionProtocolPsE4lazys0aB0Vy8ElementsQzGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : LazyCollectionProtocol>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s22LazyCollectionProtocolPsE4lazys0aB0Vy8ElementsQzGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "lazy",
           "printedName": "lazy",
-          "declKind": "Var",
-          "usr": "s:s22LazyCollectionProtocolPssAA8ElementsRpzrlE4lazyADvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -66467,39 +75729,35 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s22LazyCollectionProtocolPssAA8ElementsRpzrlE4lazyADvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : LazyCollectionProtocol, Self.Elements : LazyCollectionProtocol>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Elements"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s22LazyCollectionProtocolPssAA8ElementsRpzrlE4lazyADvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : LazyCollectionProtocol, Self.Elements : LazyCollectionProtocol>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s22LazyCollectionProtocolPssAA8ElementsRpzrlE4lazyADvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsE3mapys0a3MapB0Vy8ElementsQzqd__Gqd__7ElementQzclF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, U where Self : LazyCollectionProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyMapCollection",
               "printedName": "LazyMapCollection<Self.Elements, U>",
-              "usr": "s:s17LazyMapCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -66511,7 +75769,8 @@
                   "name": "GenericTypeParam",
                   "printedName": "U"
                 }
-              ]
+              ],
+              "usr": "s:s17LazyMapCollectionV"
             },
             {
               "kind": "TypeFunc",
@@ -66537,33 +75796,32 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsE3mapys0a3MapB0Vy8ElementsQzqd__Gqd__7ElementQzclF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, U where Self : LazyCollectionProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsE6prefix5whiles0a11PrefixWhileB0Vy8ElementsQzGSb7ElementQzc_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LazyCollectionProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyPrefixWhileCollection",
               "printedName": "LazyPrefixWhileCollection<Self.Elements>",
-              "usr": "s:s25LazyPrefixWhileCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Elements"
                 }
-              ]
+              ],
+              "usr": "s:s25LazyPrefixWhileCollectionV"
             },
             {
               "kind": "TypeFunc",
@@ -66590,74 +75848,69 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsE6prefix5whiles0a11PrefixWhileB0Vy8ElementsQzGSb7ElementQzc_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : LazyCollectionProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "reversed",
           "printedName": "reversed()",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsSKRzSK8Elementss0a8SequenceC0PRpzrlE8reverseds0aB0Vys08ReversedB0VyAFGGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self : LazyCollectionProtocol, Self.Elements : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyCollection",
               "printedName": "LazyCollection<ReversedCollection<Self.Elements>>",
-              "usr": "s:s14LazyCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ReversedCollection",
                   "printedName": "ReversedCollection<Self.Elements>",
-                  "usr": "s:s18ReversedCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Self.Elements"
                     }
-                  ]
+                  ],
+                  "usr": "s:s18ReversedCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:s14LazyCollectionV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsSKRzSK8Elementss0a8SequenceC0PRpzrlE8reverseds0aB0Vys08ReversedB0VyAFGGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection, Self : LazyCollectionProtocol, Self.Elements : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "flatMap",
           "printedName": "flatMap(_:)",
-          "declKind": "Func",
-          "usr": "s:s22LazyCollectionProtocolPsE7flatMapys0aeB0Vys0a6FilterB0VyAEy8ElementsQzqd__SgGGqd__GAJ7ElementQzclF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, ElementOfResult where Self : LazyCollectionProtocol>",
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyMapCollection",
               "printedName": "LazyMapCollection<LazyFilterCollection<LazyMapCollection<Self.Elements, ElementOfResult?>>, ElementOfResult>",
-              "usr": "s:s17LazyMapCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "LazyFilterCollection",
                   "printedName": "LazyFilterCollection<LazyMapCollection<Self.Elements, ElementOfResult?>>",
-                  "usr": "s:s20LazyFilterCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "LazyMapCollection",
                       "printedName": "LazyMapCollection<Self.Elements, ElementOfResult?>",
-                      "usr": "s:s17LazyMapCollectionV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -66668,25 +75921,28 @@
                           "kind": "TypeNominal",
                           "name": "Optional",
                           "printedName": "ElementOfResult?",
-                          "usr": "s:Sq",
                           "children": [
                             {
                               "kind": "TypeNominal",
                               "name": "GenericTypeParam",
                               "printedName": "ElementOfResult"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         }
-                      ]
+                      ],
+                      "usr": "s:s17LazyMapCollectionV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s20LazyFilterCollectionV"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "ElementOfResult"
                 }
-              ]
+              ],
+              "usr": "s:s17LazyMapCollectionV"
             },
             {
               "kind": "TypeFunc",
@@ -66697,14 +75953,14 @@
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "ElementOfResult?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "ElementOfResult"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -66720,59 +75976,52 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s22LazyCollectionProtocolPsE7flatMapys0aeB0Vys0a6FilterB0VyAEy8ElementsQzqd__SgGGqd__GAJ7ElementQzclF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, ElementOfResult where Self : LazyCollectionProtocol>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s22LazyCollectionProtocolP",
+      "moduleName": "Swift",
+      "genericSig": "<Self : Collection, Self : LazySequenceProtocol, Self.Elements : Collection>",
+      "conformingProtocols": [
+        "Collection",
+        "LazySequenceProtocol",
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "LazyCollection",
       "printedName": "LazyCollection",
-      "declKind": "Struct",
-      "usr": "s:s14LazyCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Collection>",
-      "conformingProtocols": [
-        "LazyCollectionProtocol",
-        "LazySequenceProtocol",
-        "Sequence",
-        "Collection",
-        "BidirectionalCollection",
-        "RandomAccessCollection"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Elements",
           "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s14LazyCollectionV8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Base"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s14LazyCollectionV8Elementsa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "Var",
           "name": "elements",
           "printedName": "elements",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionV8elementsxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -66783,50 +76032,46 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionV8elementsxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionV8elementsxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionV8elementsxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s14LazyCollectionV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Iterator"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s14LazyCollectionV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s14LazyCollectionV12makeIterator0D0QzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -66840,19 +76085,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14LazyCollectionV12makeIterator0D0QzyF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -66864,11 +76109,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -66876,72 +76116,72 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s14LazyCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s14LazyCollectionV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s14LazyCollectionV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Index"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s14LazyCollectionV5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s14LazyCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Indices"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s14LazyCollectionV7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionV10startIndex0D0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -66952,32 +76192,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionV10startIndex0D0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Index"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionV10startIndex0D0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionV10startIndex0D0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionV8endIndex0D0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -66988,32 +76226,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionV8endIndex0D0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Index"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionV8endIndex0D0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionV8endIndex0D0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionV7indices7IndicesQzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -67024,33 +76260,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionV7indices7IndicesQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Indices"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionV7indices7IndicesQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionV7indices7IndicesQzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s14LazyCollectionV5index5after5IndexQzAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -67076,19 +76309,57 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14LazyCollectionV5index5after5IndexQzAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Element",
+              "printedName": "LazyCollection<Base>.Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "LazyCollection<Base>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ]
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s14LazyCollectionVy7ElementQz5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "isEmpty",
           "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionV7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -67100,11 +76371,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionV7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -67112,21 +76378,24 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionV7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionV7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -67138,11 +76407,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -67150,74 +76414,74 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "first",
           "printedName": "first",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionV5first7ElementQzSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Base.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionV5first7ElementQzSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Base.Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Base.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionV5first7ElementQzSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionV5first7ElementQzSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s14LazyCollectionV5index_8offsetBy5IndexQzAF_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -67249,26 +76513,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14LazyCollectionV5index_8offsetBy5IndexQzAF_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s14LazyCollectionV5index_8offsetBy07limitedE05IndexQzSgAG_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "LazyCollection<Base>.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -67282,7 +76544,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -67314,20 +76577,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14LazyCollectionV5index_8offsetBy07limitedE05IndexQzSgAG_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s14LazyCollectionV8distance4from2toSi5IndexQz_AGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -67359,53 +76621,52 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14LazyCollectionV8distance4from2toSi5IndexQz_AGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s14LazyCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<LazyCollection<Base>>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "LazyCollection",
                   "printedName": "LazyCollection<Base>",
-                  "usr": "s:s14LazyCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Base"
                     }
-                  ]
+                  ],
+                  "usr": "s:s14LazyCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s14LazyCollectionV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s14LazyCollectionVsSKRzrlE5index6before5IndexQzAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -67431,83 +76692,107 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s14LazyCollectionVsSKRzrlE5index6before5IndexQzAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "last",
           "printedName": "last",
-          "declKind": "Var",
-          "usr": "s:s14LazyCollectionVsSKRzrlE4last7ElementQzSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Base.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s14LazyCollectionVsSKRzrlE4last7ElementQzSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Base.Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Base.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s14LazyCollectionVsSKRzrlE4last7ElementQzSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : BidirectionalCollection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s14LazyCollectionVsSKRzrlE4last7ElementQzSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s14LazyCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<Base where Base : Collection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "LazyCollectionProtocol",
+        "LazySequenceProtocol",
+        "Sequence",
+        "Collection",
+        "BidirectionalCollection",
+        "RandomAccessCollection"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "LazySequenceProtocol",
       "printedName": "LazySequenceProtocol",
-      "declKind": "Protocol",
-      "usr": "s:s20LazySequenceProtocolP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Sequence, Self.Element == Self.Elements.Element, Self.Elements : Sequence>",
-      "conformingProtocols": [
-        "Sequence"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Elements",
+          "printedName": "Elements",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:s20LazySequenceProtocolP8ElementsQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Var",
           "name": "elements",
           "printedName": "elements",
-          "declKind": "Var",
-          "usr": "s:s20LazySequenceProtocolP8elements8ElementsQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -67518,46 +76803,41 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20LazySequenceProtocolP8elements8ElementsQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : LazySequenceProtocol>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Elements"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20LazySequenceProtocolP8elements8ElementsQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : LazySequenceProtocol>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s20LazySequenceProtocolP8elements8ElementsQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:s20LazySequenceProtocolPsE4drop5whiles0a9DropWhileB0Vy8ElementsQzGSb7ElementQzc_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LazySequenceProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyDropWhileSequence",
               "printedName": "LazyDropWhileSequence<Self.Elements>",
-              "usr": "s:s21LazyDropWhileSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Elements"
                 }
-              ]
+              ],
+              "usr": "s:s21LazyDropWhileSequenceV"
             },
             {
               "kind": "TypeFunc",
@@ -67584,33 +76864,32 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazySequenceProtocolPsE4drop5whiles0a9DropWhileB0Vy8ElementsQzGSb7ElementQzc_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : LazySequenceProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:s20LazySequenceProtocolPsE6filterys0a6FilterB0Vy8ElementsQzGSb7ElementQzcF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LazySequenceProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyFilterSequence",
               "printedName": "LazyFilterSequence<Self.Elements>",
-              "usr": "s:s18LazyFilterSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Elements"
                 }
-              ]
+              ],
+              "usr": "s:s18LazyFilterSequenceV"
             },
             {
               "kind": "TypeFunc",
@@ -67637,38 +76916,34 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazySequenceProtocolPsE6filterys0a6FilterB0Vy8ElementsQzGSb7ElementQzcF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : LazySequenceProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "flatMap",
           "printedName": "flatMap(_:)",
-          "declKind": "Func",
-          "usr": "s:s20LazySequenceProtocolPsE7flatMapys0aB0Vys07FlattenB0Vys0aeB0Vy8ElementsQzqd__GGGqd__7ElementQzcSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, SegmentOfResult where Self : LazySequenceProtocol, SegmentOfResult : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazySequence",
               "printedName": "LazySequence<FlattenSequence<LazyMapSequence<Self.Elements, SegmentOfResult>>>",
-              "usr": "s:s12LazySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "FlattenSequence",
                   "printedName": "FlattenSequence<LazyMapSequence<Self.Elements, SegmentOfResult>>",
-                  "usr": "s:s15FlattenSequenceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "LazyMapSequence",
                       "printedName": "LazyMapSequence<Self.Elements, SegmentOfResult>",
-                      "usr": "s:s15LazyMapSequenceV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -67680,11 +76955,14 @@
                           "name": "GenericTypeParam",
                           "printedName": "SegmentOfResult"
                         }
-                      ]
+                      ],
+                      "usr": "s:s15LazyMapSequenceV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s15FlattenSequenceV"
                 }
-              ]
+              ],
+              "usr": "s:s12LazySequenceV"
             },
             {
               "kind": "TypeFunc",
@@ -67710,38 +76988,34 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazySequenceProtocolPsE7flatMapys0aB0Vys07FlattenB0Vys0aeB0Vy8ElementsQzqd__GGGqd__7ElementQzcSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, SegmentOfResult where Self : LazySequenceProtocol, SegmentOfResult : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "compactMap",
           "printedName": "compactMap(_:)",
-          "declKind": "Func",
-          "usr": "s:s20LazySequenceProtocolPsE10compactMapys0aeB0Vys0a6FilterB0VyAEy8ElementsQzqd__SgGGqd__GAJ7ElementQzclF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, ElementOfResult where Self : LazySequenceProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyMapSequence",
               "printedName": "LazyMapSequence<LazyFilterSequence<LazyMapSequence<Self.Elements, ElementOfResult?>>, ElementOfResult>",
-              "usr": "s:s15LazyMapSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "LazyFilterSequence",
                   "printedName": "LazyFilterSequence<LazyMapSequence<Self.Elements, ElementOfResult?>>",
-                  "usr": "s:s18LazyFilterSequenceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "LazyMapSequence",
                       "printedName": "LazyMapSequence<Self.Elements, ElementOfResult?>",
-                      "usr": "s:s15LazyMapSequenceV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -67752,25 +77026,28 @@
                           "kind": "TypeNominal",
                           "name": "Optional",
                           "printedName": "ElementOfResult?",
-                          "usr": "s:Sq",
                           "children": [
                             {
                               "kind": "TypeNominal",
                               "name": "GenericTypeParam",
                               "printedName": "ElementOfResult"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         }
-                      ]
+                      ],
+                      "usr": "s:s15LazyMapSequenceV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s18LazyFilterSequenceV"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "ElementOfResult"
                 }
-              ]
+              ],
+              "usr": "s:s15LazyMapSequenceV"
             },
             {
               "kind": "TypeFunc",
@@ -67781,14 +77058,14 @@
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "ElementOfResult?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "ElementOfResult"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -67804,55 +77081,54 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazySequenceProtocolPsE10compactMapys0aeB0Vys0a6FilterB0VyAEy8ElementsQzqd__SgGGqd__GAJ7ElementQzclF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, ElementOfResult where Self : LazySequenceProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "joined",
           "printedName": "joined()",
-          "declKind": "Func",
-          "usr": "s:s20LazySequenceProtocolPsST7ElementRpzrlE6joineds0aB0Vys07FlattenB0Vy8ElementsQzGGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LazySequenceProtocol, Self.Element : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazySequence",
               "printedName": "LazySequence<FlattenSequence<Self.Elements>>",
-              "usr": "s:s12LazySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "FlattenSequence",
                   "printedName": "FlattenSequence<Self.Elements>",
-                  "usr": "s:s15FlattenSequenceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Self.Elements"
                     }
-                  ]
+                  ],
+                  "usr": "s:s15FlattenSequenceV"
                 }
-              ]
+              ],
+              "usr": "s:s12LazySequenceV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazySequenceProtocolPsST7ElementRpzrlE6joineds0aB0Vys07FlattenB0Vy8ElementsQzGGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : LazySequenceProtocol, Self.Element : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "elements",
           "printedName": "elements",
-          "declKind": "Var",
-          "usr": "s:s20LazySequenceProtocolPs8ElementsQzRszrlE8elementsxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -67863,84 +77139,80 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20LazySequenceProtocolPs8ElementsQzRszrlE8elementsxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : LazySequenceProtocol, Self == Self.Elements>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20LazySequenceProtocolPs8ElementsQzRszrlE8elementsxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : LazySequenceProtocol, Self == Self.Elements>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20LazySequenceProtocolPs8ElementsQzRszrlE8elementsxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "lazy",
           "printedName": "lazy",
-          "declKind": "Var",
-          "usr": "s:s20LazySequenceProtocolPsE4lazys0aB0Vy8ElementsQzGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazySequence",
               "printedName": "LazySequence<Self.Elements>",
-              "usr": "s:s12LazySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Elements"
                 }
-              ]
+              ],
+              "usr": "s:s12LazySequenceV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20LazySequenceProtocolPsE4lazys0aB0Vy8ElementsQzGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : LazySequenceProtocol>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "LazySequence",
                   "printedName": "LazySequence<Self.Elements>",
-                  "usr": "s:s12LazySequenceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Self.Elements"
                     }
-                  ]
+                  ],
+                  "usr": "s:s12LazySequenceV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20LazySequenceProtocolPsE4lazys0aB0Vy8ElementsQzGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : LazySequenceProtocol>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20LazySequenceProtocolPsE4lazys0aB0Vy8ElementsQzGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "lazy",
           "printedName": "lazy",
-          "declKind": "Var",
-          "usr": "s:s20LazySequenceProtocolPssAA8ElementsRpzrlE4lazyADvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -67951,39 +77223,35 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20LazySequenceProtocolPssAA8ElementsRpzrlE4lazyADvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : LazySequenceProtocol, Self.Elements : LazySequenceProtocol>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Elements"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20LazySequenceProtocolPssAA8ElementsRpzrlE4lazyADvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : LazySequenceProtocol, Self.Elements : LazySequenceProtocol>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20LazySequenceProtocolPssAA8ElementsRpzrlE4lazyADvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:s20LazySequenceProtocolPsE3mapys0a3MapB0Vy8ElementsQzqd__Gqd__7ElementQzclF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, U where Self : LazySequenceProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyMapSequence",
               "printedName": "LazyMapSequence<Self.Elements, U>",
-              "usr": "s:s15LazyMapSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -67995,7 +77263,8 @@
                   "name": "GenericTypeParam",
                   "printedName": "U"
                 }
-              ]
+              ],
+              "usr": "s:s15LazyMapSequenceV"
             },
             {
               "kind": "TypeFunc",
@@ -68021,33 +77290,32 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazySequenceProtocolPsE3mapys0a3MapB0Vy8ElementsQzqd__Gqd__7ElementQzclF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, U where Self : LazySequenceProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:s20LazySequenceProtocolPsE6prefix5whiles0a11PrefixWhileB0Vy8ElementsQzGSb7ElementQzc_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LazySequenceProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyPrefixWhileSequence",
               "printedName": "LazyPrefixWhileSequence<Self.Elements>",
-              "usr": "s:s23LazyPrefixWhileSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Elements"
                 }
-              ]
+              ],
+              "usr": "s:s23LazyPrefixWhileSequenceV"
             },
             {
               "kind": "TypeFunc",
@@ -68074,38 +77342,34 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazySequenceProtocolPsE6prefix5whiles0a11PrefixWhileB0Vy8ElementsQzGSb7ElementQzc_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : LazySequenceProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "flatMap",
           "printedName": "flatMap(_:)",
-          "declKind": "Func",
-          "usr": "s:s20LazySequenceProtocolPsE7flatMapys0aeB0Vys0a6FilterB0VyAEy8ElementsQzqd__SgGGqd__GAJ7ElementQzclF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, ElementOfResult where Self : LazySequenceProtocol>",
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyMapSequence",
               "printedName": "LazyMapSequence<LazyFilterSequence<LazyMapSequence<Self.Elements, ElementOfResult?>>, ElementOfResult>",
-              "usr": "s:s15LazyMapSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "LazyFilterSequence",
                   "printedName": "LazyFilterSequence<LazyMapSequence<Self.Elements, ElementOfResult?>>",
-                  "usr": "s:s18LazyFilterSequenceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "LazyMapSequence",
                       "printedName": "LazyMapSequence<Self.Elements, ElementOfResult?>",
-                      "usr": "s:s15LazyMapSequenceV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -68116,25 +77380,28 @@
                           "kind": "TypeNominal",
                           "name": "Optional",
                           "printedName": "ElementOfResult?",
-                          "usr": "s:Sq",
                           "children": [
                             {
                               "kind": "TypeNominal",
                               "name": "GenericTypeParam",
                               "printedName": "ElementOfResult"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         }
-                      ]
+                      ],
+                      "usr": "s:s15LazyMapSequenceV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s18LazyFilterSequenceV"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "ElementOfResult"
                 }
-              ]
+              ],
+              "usr": "s:s15LazyMapSequenceV"
             },
             {
               "kind": "TypeFunc",
@@ -68145,14 +77412,14 @@
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "ElementOfResult?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "ElementOfResult"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -68168,124 +77435,118 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20LazySequenceProtocolPsE7flatMapys0aeB0Vys0a6FilterB0VyAEy8ElementsQzqd__SgGGqd__GAJ7ElementQzclF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, ElementOfResult where Self : LazySequenceProtocol>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s20LazySequenceProtocolP",
+      "moduleName": "Swift",
+      "genericSig": "<Self : Sequence, Self.Element == Self.Elements.Element, Self.Elements : Sequence>",
+      "conformingProtocols": [
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "LazySequence",
       "printedName": "LazySequence",
-      "declKind": "Struct",
-      "usr": "s:s12LazySequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Sequence>",
-      "conformingProtocols": [
-        "_SequenceWrapper",
-        "Sequence",
-        "LazySequenceProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Base",
           "printedName": "Base",
-          "declKind": "TypeAlias",
-          "usr": "s:s12LazySequenceV4Basea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Base"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s12LazySequenceV4Basea",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s12LazySequenceV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Iterator"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s12LazySequenceV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s12LazySequenceV03SubB0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.SubSequence"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s12LazySequenceV03SubB0a",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s12LazySequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s12LazySequenceV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Elements",
           "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s12LazySequenceV8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Base"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s12LazySequenceV8Elementsa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>"
         },
         {
           "kind": "Var",
           "name": "elements",
           "printedName": "elements",
-          "declKind": "Var",
-          "usr": "s:s12LazySequenceV8elementsxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -68296,37 +77557,44 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12LazySequenceV8elementsxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12LazySequenceV8elementsxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12LazySequenceV8elementsxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s12LazySequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<Base where Base : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "_SequenceWrapper",
+        "Sequence",
+        "LazySequenceProtocol"
       ]
     },
     {
       "kind": "Function",
       "name": "withExtendedLifetime",
       "printedName": "withExtendedLifetime(_:_:)",
-      "declKind": "Func",
-      "usr": "s:s20withExtendedLifetimeyq_x_q_yKXEtKr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, Result>",
-      "throwing": true,
-      "declAttributes": [
-        "Rethrows",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -68342,9 +77610,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "() throws -> Result",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -68356,24 +77621,26 @@
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         }
-      ]
+      ],
+      "declKind": "Func",
+      "usr": "s:s20withExtendedLifetimeyq_x_q_yKXEtKr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<T, Result>",
+      "declAttributes": [
+        "Rethrows",
+        "Inlinable"
+      ],
+      "throwing": true
     },
     {
       "kind": "Function",
       "name": "withExtendedLifetime",
       "printedName": "withExtendedLifetime(_:_:)",
-      "declKind": "Func",
-      "usr": "s:s20withExtendedLifetimeyq_x_q_xKXEtKr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, Result>",
-      "throwing": true,
-      "declAttributes": [
-        "Rethrows",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -68389,9 +77656,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "(T) throws -> Result",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -68410,24 +77674,26 @@
                 }
               ]
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         }
-      ]
+      ],
+      "declKind": "Func",
+      "usr": "s:s20withExtendedLifetimeyq_x_q_xKXEtKr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<T, Result>",
+      "declAttributes": [
+        "Rethrows",
+        "Inlinable"
+      ],
+      "throwing": true
     },
     {
       "kind": "Function",
       "name": "withUnsafeMutablePointer",
       "printedName": "withUnsafeMutablePointer(to:_:)",
-      "declKind": "Func",
-      "usr": "s:s24withUnsafeMutablePointer2to_q_xz_q_SpyxGKXEtKr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, Result>",
-      "throwing": true,
-      "declAttributes": [
-        "Rethrows",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -68443,9 +77709,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "(UnsafeMutablePointer<T>) throws -> Result",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -68456,104 +77719,105 @@
               "kind": "TypeNominal",
               "name": "Paren",
               "printedName": "(UnsafeMutablePointer<T>)",
-              "usr": "s:Sp",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafeMutablePointer",
                   "printedName": "UnsafeMutablePointer<T>",
-                  "usr": "s:Sp",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "T"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         }
-      ]
+      ],
+      "declKind": "Func",
+      "usr": "s:s24withUnsafeMutablePointer2to_q_xz_q_SpyxGKXEtKr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<T, Result>",
+      "declAttributes": [
+        "Rethrows",
+        "Inlinable"
+      ],
+      "throwing": true
     },
     {
       "kind": "Function",
       "name": "withUnsafePointer",
       "printedName": "withUnsafePointer(to:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "Result"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "T"
+        },
+        {
+          "kind": "TypeFunc",
+          "name": "Function",
+          "printedName": "(UnsafePointer<T>) throws -> Result",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Result"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Paren",
+              "printedName": "(UnsafePointer<T>)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafePointer",
+                  "printedName": "UnsafePointer<T>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "T"
+                    }
+                  ],
+                  "usr": "s:SP"
+                }
+              ],
+              "usr": "s:SP"
+            }
+          ],
+          "typeAttributes": [
+            "noescape"
+          ]
+        }
+      ],
       "declKind": "Func",
       "usr": "s:s17withUnsafePointer2to_q_x_q_SPyxGKXEtKr0_lF",
-      "location": "",
       "moduleName": "Swift",
       "genericSig": "<T, Result>",
-      "throwing": true,
       "declAttributes": [
         "Rethrows",
         "Inlinable"
       ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "Result"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        },
-        {
-          "kind": "TypeFunc",
-          "name": "Function",
-          "printedName": "(UnsafePointer<T>) throws -> Result",
-          "typeAttributes": [
-            "noescape"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Result"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Paren",
-              "printedName": "(UnsafePointer<T>)",
-              "usr": "s:SP",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafePointer",
-                  "printedName": "UnsafePointer<T>",
-                  "usr": "s:SP",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "T"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        }
-      ]
+      "throwing": true
     },
     {
       "kind": "Function",
       "name": "withUnsafePointer",
       "printedName": "withUnsafePointer(to:_:)",
-      "declKind": "Func",
-      "usr": "s:s17withUnsafePointer2to_q_xz_q_SPyxGKXEtKr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, Result>",
-      "throwing": true,
-      "declAttributes": [
-        "Rethrows",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -68569,9 +77833,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "(UnsafePointer<T>) throws -> Result",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -68582,62 +77843,53 @@
               "kind": "TypeNominal",
               "name": "Paren",
               "printedName": "(UnsafePointer<T>)",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafePointer",
                   "printedName": "UnsafePointer<T>",
-                  "usr": "s:SP",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "T"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         }
-      ]
+      ],
+      "declKind": "Func",
+      "usr": "s:s17withUnsafePointer2to_q_xz_q_SPyxGKXEtKr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<T, Result>",
+      "declAttributes": [
+        "Rethrows",
+        "Inlinable"
+      ],
+      "throwing": true
     },
     {
       "kind": "TypeDecl",
       "name": "ManagedBuffer",
       "printedName": "ManagedBuffer",
-      "declKind": "Class",
-      "usr": "s:s13ManagedBufferC",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Header, Element>",
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Function",
           "name": "create",
           "printedName": "create(minimumCapacity:makingHeaderWith:)",
-          "declKind": "Func",
-          "usr": "s:s13ManagedBufferC6create15minimumCapacity16makingHeaderWithAByxq_GSi_xAFKXEtKFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element>",
-          "static": true,
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Final",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ManagedBuffer",
               "printedName": "ManagedBuffer<Header, Element>",
-              "usr": "s:s13ManagedBufferC",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -68649,7 +77901,8 @@
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s13ManagedBufferC"
             },
             {
               "kind": "TypeNominal",
@@ -68661,9 +77914,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(ManagedBuffer<Header, Element>) throws -> Header",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -68674,13 +77924,11 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(ManagedBuffer<Header, Element>)",
-                  "usr": "s:s13ManagedBufferC",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "ManagedBuffer",
                       "printedName": "ManagedBuffer<Header, Element>",
-                      "usr": "s:s13ManagedBufferC",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -68692,26 +77940,34 @@
                           "name": "GenericTypeParam",
                           "printedName": "Element"
                         }
-                      ]
+                      ],
+                      "usr": "s:s13ManagedBufferC"
                     }
-                  ]
+                  ],
+                  "usr": "s:s13ManagedBufferC"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13ManagedBufferC6create15minimumCapacity16makingHeaderWithAByxq_GSi_xAFKXEtKFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Header, Element>",
+          "static": true,
+          "declAttributes": [
+            "Rethrows",
+            "Final",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Var",
           "name": "capacity",
           "printedName": "capacity",
-          "declKind": "Var",
-          "usr": "s:s13ManagedBufferC8capacitySivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Final",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -68723,14 +77979,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13ManagedBufferC8capacitySivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Header, Element>",
-              "declAttributes": [
-                "Final"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -68738,25 +77986,28 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13ManagedBufferC8capacitySivg",
+              "moduleName": "Swift",
+              "genericSig": "<Header, Element>",
+              "declAttributes": [
+                "Final"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13ManagedBufferC8capacitySivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Final",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "withUnsafeMutablePointerToHeader",
           "printedName": "withUnsafeMutablePointerToHeader(_:)",
-          "declKind": "Func",
-          "usr": "s:s13ManagedBufferC32withUnsafeMutablePointerToHeaderyqd__qd__SpyxGKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Final",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -68767,9 +78018,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafeMutablePointer<Header>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -68780,42 +78028,44 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafeMutablePointer<Header>)",
-                  "usr": "s:Sp",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafeMutablePointer",
                       "printedName": "UnsafeMutablePointer<Header>",
-                      "usr": "s:Sp",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
                           "printedName": "Header"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sp"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeMutablePointerToElements",
-          "printedName": "withUnsafeMutablePointerToElements(_:)",
+          ],
           "declKind": "Func",
-          "usr": "s:s13ManagedBufferC34withUnsafeMutablePointerToElementsyqd__qd__Spyq_GKXEKlF",
-          "location": "",
+          "usr": "s:s13ManagedBufferC32withUnsafeMutablePointerToHeaderyqd__qd__SpyxGKXEKlF",
           "moduleName": "Swift",
           "genericSig": "<Header, Element, R>",
-          "throwing": true,
           "declAttributes": [
             "Rethrows",
             "Final",
             "Inlinable"
           ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeMutablePointerToElements",
+          "printedName": "withUnsafeMutablePointerToElements(_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -68826,9 +78076,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafeMutablePointer<Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -68839,42 +78086,44 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafeMutablePointer<Element>)",
-                  "usr": "s:Sp",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafeMutablePointer",
                       "printedName": "UnsafeMutablePointer<Element>",
-                      "usr": "s:Sp",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
                           "printedName": "Element"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sp"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "withUnsafeMutablePointers",
-          "printedName": "withUnsafeMutablePointers(_:)",
+          ],
           "declKind": "Func",
-          "usr": "s:s13ManagedBufferC25withUnsafeMutablePointersyqd__qd__SpyxG_Spyq_GtKXEKlF",
-          "location": "",
+          "usr": "s:s13ManagedBufferC34withUnsafeMutablePointerToElementsyqd__qd__Spyq_GKXEKlF",
           "moduleName": "Swift",
           "genericSig": "<Header, Element, R>",
-          "throwing": true,
           "declAttributes": [
             "Rethrows",
             "Final",
             "Inlinable"
           ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "withUnsafeMutablePointers",
+          "printedName": "withUnsafeMutablePointers(_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -68885,9 +78134,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafeMutablePointer<Header>, UnsafeMutablePointer<Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -68903,45 +78149,51 @@
                       "kind": "TypeNominal",
                       "name": "UnsafeMutablePointer",
                       "printedName": "UnsafeMutablePointer<Header>",
-                      "usr": "s:Sp",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
                           "printedName": "Header"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sp"
                     },
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafeMutablePointer",
                       "printedName": "UnsafeMutablePointer<Element>",
-                      "usr": "s:Sp",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
                           "printedName": "Element"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sp"
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13ManagedBufferC25withUnsafeMutablePointersyqd__qd__SpyxG_Spyq_GtKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Header, Element, R>",
+          "declAttributes": [
+            "Rethrows",
+            "Final",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Var",
           "name": "header",
           "printedName": "header",
-          "declKind": "Var",
-          "usr": "s:s13ManagedBufferC6headerxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Final"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -68952,36 +78204,27 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13ManagedBufferC6headerxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Header, Element>",
-              "declAttributes": [
-                "Transparent",
-                "Final"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Header"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13ManagedBufferC6headerxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Header, Element>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent",
+                "Final"
               ]
             },
             {
               "kind": "Setter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13ManagedBufferC6headerxvs",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Header, Element>",
-              "declAttributes": [
-                "Transparent",
-                "Final"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -68993,48 +78236,50 @@
                   "name": "GenericTypeParam",
                   "printedName": "Header"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13ManagedBufferC6headerxvs",
+              "moduleName": "Swift",
+              "genericSig": "<Header, Element>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent",
+                "Final"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s13ManagedBufferC6headerxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Final"
+          ],
+          "hasStorage": true
         }
+      ],
+      "declKind": "Class",
+      "usr": "s:s13ManagedBufferC",
+      "moduleName": "Swift",
+      "genericSig": "<Header, Element>",
+      "isOpen": true,
+      "declAttributes": [
+        "FixedLayout"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "ManagedBufferPointer",
       "printedName": "ManagedBufferPointer",
-      "declKind": "Struct",
-      "usr": "s:s20ManagedBufferPointerV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Header, Element>",
-      "conformingProtocols": [
-        "Equatable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(bufferClass:minimumCapacity:makingHeaderWith:)",
-          "declKind": "Constructor",
-          "usr": "s:s20ManagedBufferPointerV11bufferClass15minimumCapacity16makingHeaderWithAByxq_GyXlXp_SixyXl_SiyXlXEtKXEtKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ManagedBufferPointer",
               "printedName": "ManagedBufferPointer<Header, Element>",
-              "usr": "s:s20ManagedBufferPointerV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -69046,7 +78291,8 @@
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s20ManagedBufferPointerV"
             },
             {
               "kind": "TypeNameAlias",
@@ -69077,9 +78323,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(AnyObject, (AnyObject) -> Int) throws -> Header",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -69107,9 +78350,6 @@
                       "kind": "TypeFunc",
                       "name": "Function",
                       "printedName": "(AnyObject) -> Int",
-                      "typeAttributes": [
-                        "noescape"
-                      ],
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -69136,32 +78376,38 @@
                             }
                           ]
                         }
+                      ],
+                      "typeAttributes": [
+                        "noescape"
                       ]
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s20ManagedBufferPointerV11bufferClass15minimumCapacity16makingHeaderWithAByxq_GyXlXp_SixyXl_SiyXlXEtKXEtKcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Header, Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(unsafeBufferObject:)",
-          "declKind": "Constructor",
-          "usr": "s:s20ManagedBufferPointerV06unsafeB6ObjectAByxq_GyXl_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ManagedBufferPointer",
               "printedName": "ManagedBufferPointer<Header, Element>",
-              "usr": "s:s20ManagedBufferPointerV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -69173,7 +78419,8 @@
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s20ManagedBufferPointerV"
             },
             {
               "kind": "TypeNameAlias",
@@ -69187,19 +78434,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s20ManagedBufferPointerV06unsafeB6ObjectAByxq_GyXl_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Header, Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "header",
           "printedName": "header",
-          "declKind": "Var",
-          "usr": "s:s20ManagedBufferPointerV6headerxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -69210,35 +78457,26 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20ManagedBufferPointerV6headerxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Header, Element>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Header"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20ManagedBufferPointerV6headerxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Header, Element>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Setter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20ManagedBufferPointerV6headerxvs",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Header, Element>",
-              "mutating": true,
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -69250,21 +78488,29 @@
                   "name": "GenericTypeParam",
                   "printedName": "Header"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20ManagedBufferPointerV6headerxvs",
+              "moduleName": "Swift",
+              "genericSig": "<Header, Element>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ],
+              "mutating": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20ManagedBufferPointerV6headerxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "buffer",
           "printedName": "buffer",
-          "declKind": "Var",
-          "usr": "s:s20ManagedBufferPointerV6bufferyXlvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -69282,11 +78528,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20ManagedBufferPointerV6bufferyXlvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Header, Element>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -69300,21 +78541,24 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20ManagedBufferPointerV6bufferyXlvg",
+              "moduleName": "Swift",
+              "genericSig": "<Header, Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20ManagedBufferPointerV6bufferyXlvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "capacity",
           "printedName": "capacity",
-          "declKind": "Var",
-          "usr": "s:s20ManagedBufferPointerV8capacitySivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -69326,11 +78570,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s20ManagedBufferPointerV8capacitySivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Header, Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -69338,24 +78577,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s20ManagedBufferPointerV8capacitySivg",
+              "moduleName": "Swift",
+              "genericSig": "<Header, Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s20ManagedBufferPointerV8capacitySivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "withUnsafeMutablePointerToHeader",
           "printedName": "withUnsafeMutablePointerToHeader(_:)",
-          "declKind": "Func",
-          "usr": "s:s20ManagedBufferPointerV017withUnsafeMutableC8ToHeaderyqd__qd__SpyxGKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -69366,9 +78605,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafeMutablePointer<Header>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -69379,41 +78615,43 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafeMutablePointer<Header>)",
-                  "usr": "s:Sp",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafeMutablePointer",
                       "printedName": "UnsafeMutablePointer<Header>",
-                      "usr": "s:Sp",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
                           "printedName": "Header"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sp"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s20ManagedBufferPointerV017withUnsafeMutableC8ToHeaderyqd__qd__SpyxGKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Header, Element, R>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "withUnsafeMutablePointerToElements",
           "printedName": "withUnsafeMutablePointerToElements(_:)",
-          "declKind": "Func",
-          "usr": "s:s20ManagedBufferPointerV017withUnsafeMutableC10ToElementsyqd__qd__Spyq_GKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -69424,9 +78662,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafeMutablePointer<Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -69437,41 +78672,43 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafeMutablePointer<Element>)",
-                  "usr": "s:Sp",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafeMutablePointer",
                       "printedName": "UnsafeMutablePointer<Element>",
-                      "usr": "s:Sp",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
                           "printedName": "Element"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sp"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s20ManagedBufferPointerV017withUnsafeMutableC10ToElementsyqd__qd__Spyq_GKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Header, Element, R>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "withUnsafeMutablePointers",
           "printedName": "withUnsafeMutablePointers(_:)",
-          "declKind": "Func",
-          "usr": "s:s20ManagedBufferPointerV25withUnsafeMutablePointersyqd__qd__SpyxG_Spyq_GtKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element, R>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -69482,9 +78719,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafeMutablePointer<Header>, UnsafeMutablePointer<Element>) throws -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -69500,47 +78734,50 @@
                       "kind": "TypeNominal",
                       "name": "UnsafeMutablePointer",
                       "printedName": "UnsafeMutablePointer<Header>",
-                      "usr": "s:Sp",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
                           "printedName": "Header"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sp"
                     },
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafeMutablePointer",
                       "printedName": "UnsafeMutablePointer<Element>",
-                      "usr": "s:Sp",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
                           "printedName": "Element"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sp"
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s20ManagedBufferPointerV25withUnsafeMutablePointersyqd__qd__SpyxG_Spyq_GtKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Header, Element, R>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "isUniqueReference",
           "printedName": "isUniqueReference()",
-          "declKind": "Func",
-          "usr": "s:s20ManagedBufferPointerV17isUniqueReferenceSbyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -69548,26 +78785,25 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(bufferClass:minimumCapacity:)",
-          "declKind": "Constructor",
-          "usr": "s:s20ManagedBufferPointerV11bufferClass15minimumCapacityAByxq_GyXlXp_Sitcfc",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:s20ManagedBufferPointerV17isUniqueReferenceSbyF",
           "moduleName": "Swift",
           "genericSig": "<Header, Element>",
           "declAttributes": [
             "Inlinable"
           ],
+          "mutating": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(bufferClass:minimumCapacity:)",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ManagedBufferPointer",
               "printedName": "ManagedBufferPointer<Header, Element>",
-              "usr": "s:s20ManagedBufferPointerV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -69579,7 +78815,8 @@
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s20ManagedBufferPointerV"
             },
             {
               "kind": "TypeNameAlias",
@@ -69606,26 +78843,25 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s20ManagedBufferPointerV11bufferClass15minimumCapacityAByxq_GyXlXp_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Header, Element>",
+          "isInternal": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s20ManagedBufferPointerVyAByxq_Gs0aB0Cyxq_Gcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ManagedBufferPointer",
               "printedName": "ManagedBufferPointer<Header, Element>",
-              "usr": "s:s20ManagedBufferPointerV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -69637,13 +78873,13 @@
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s20ManagedBufferPointerV"
             },
             {
               "kind": "TypeNominal",
               "name": "ManagedBuffer",
               "printedName": "ManagedBuffer<Header, Element>",
-              "usr": "s:s13ManagedBufferC",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -69655,28 +78891,85 @@
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s13ManagedBufferC"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s20ManagedBufferPointerVyAByxq_Gs0aB0Cyxq_Gcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Header, Element>",
+          "isInternal": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ManagedBufferPointer",
+              "printedName": "ManagedBufferPointer<Header, Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Header"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:s20ManagedBufferPointerV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ManagedBufferPointer",
+              "printedName": "ManagedBufferPointer<Header, Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Header"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:s20ManagedBufferPointerV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s20ManagedBufferPointerV2eeoiySbAByxq_G_ADtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Header, Element>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:_:_:)",
-          "declKind": "Constructor",
-          "usr": "s:s20ManagedBufferPointerVss05_HeapB7Header_RzrlEyAByxq_GyXlXp_5ValueQzSitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Header, Element where Header : _HeapBufferHeader_>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ManagedBufferPointer",
               "printedName": "ManagedBufferPointer<Header, Element>",
-              "usr": "s:s20ManagedBufferPointerV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -69688,7 +78981,8 @@
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s20ManagedBufferPointerV"
             },
             {
               "kind": "TypeNameAlias",
@@ -69727,22 +79021,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s20ManagedBufferPointerVss05_HeapB7Header_RzrlEyAByxq_GyXlXp_5ValueQzSitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Header, Element where Header : _HeapBufferHeader_>",
+          "isInternal": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s20ManagedBufferPointerV",
+      "moduleName": "Swift",
+      "genericSig": "<Header, Element>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Equatable"
       ]
     },
     {
       "kind": "Function",
       "name": "isKnownUniquelyReferenced",
       "printedName": "isKnownUniquelyReferenced(_:)",
-      "declKind": "Func",
-      "usr": "s:s25isKnownUniquelyReferencedySbxzRlzClF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : AnyObject>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -69755,20 +79059,19 @@
           "name": "GenericTypeParam",
           "printedName": "T"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s25isKnownUniquelyReferencedySbxzRlzClF",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : AnyObject>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "isKnownUniquelyReferenced",
       "printedName": "isKnownUniquelyReferenced(_:)",
-      "declKind": "Func",
-      "usr": "s:s25isKnownUniquelyReferencedySbxSgzRlzClF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : AnyObject>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -69780,49 +79083,38 @@
           "kind": "TypeNominal",
           "name": "Optional",
           "printedName": "T?",
-          "usr": "s:Sq",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:Sq"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s25isKnownUniquelyReferencedySbxSgzRlzClF",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : AnyObject>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "LazyMapSequence",
       "printedName": "LazyMapSequence",
-      "declKind": "Struct",
-      "usr": "s:s15LazyMapSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base, Element where Base : Sequence>",
-      "conformingProtocols": [
-        "LazySequenceProtocol",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Elements",
           "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s15LazyMapSequenceV8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyMapSequence",
               "printedName": "LazyMapSequence<Base, Element>",
-              "usr": "s:s15LazyMapSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -69834,38 +79126,24 @@
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s15LazyMapSequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15LazyMapSequenceV8Elementsa",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Sequence>"
         },
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s15LazyMapSequenceV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Sequence>",
-          "conformingProtocols": [
-            "IteratorProtocol",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "base",
               "printedName": "base",
-              "declKind": "Var",
-              "usr": "s:s15LazyMapSequenceV8IteratorV4baseACQzvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -69876,76 +79154,75 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s15LazyMapSequenceV8IteratorV4baseACQzvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Base, Element where Base : Sequence>",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Base.Iterator"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s15LazyMapSequenceV8IteratorV4baseACQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Base, Element where Base : Sequence>"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s15LazyMapSequenceV8IteratorV4baseACQzvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s15LazyMapSequenceV8IteratorV4nextq_SgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Sequence>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s15LazyMapSequenceV8IteratorV4nextq_SgyF",
+              "moduleName": "Swift",
+              "genericSig": "<Base, Element where Base : Sequence>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s15LazyMapSequenceV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s15LazyMapSequenceV8IteratorV7Elementa",
+              "moduleName": "Swift",
+              "genericSig": "<Base, Element where Base : Sequence>",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s15LazyMapSequenceV8IteratorVACa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -69953,47 +79230,55 @@
                   "printedName": "LazyMapSequence<Base, Element>.Iterator",
                   "usr": "s:s15LazyMapSequenceV8IteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s15LazyMapSequenceV8IteratorVACa",
+              "moduleName": "Swift",
+              "genericSig": "<Base, Element where Base : Sequence>",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s15LazyMapSequenceV8IteratorV03SubC0a",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnySequence",
                   "printedName": "AnySequence<Element>",
-                  "usr": "s:s11AnySequenceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s11AnySequenceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s15LazyMapSequenceV8IteratorV03SubC0a",
+              "moduleName": "Swift",
+              "genericSig": "<Base, Element where Base : Sequence>",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s15LazyMapSequenceV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Sequence>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "Sequence"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s15LazyMapSequenceV12makeIteratorAB0E0Vyxq__GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -70001,19 +79286,19 @@
               "printedName": "LazyMapSequence<Base, Element>.Iterator",
               "usr": "s:s15LazyMapSequenceV8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15LazyMapSequenceV12makeIteratorAB0E0Vyxq__GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s15LazyMapSequenceV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -70025,11 +79310,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15LazyMapSequenceV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -70037,84 +79317,84 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15LazyMapSequenceV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Base, Element where Base : Sequence>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15LazyMapSequenceV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s15LazyMapSequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15LazyMapSequenceV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Sequence>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s15LazyMapSequenceV03SubC0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15LazyMapSequenceV03SubC0a",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Sequence>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s15LazyMapSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<Base, Element where Base : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "LazySequenceProtocol",
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "LazyMapCollection",
       "printedName": "LazyMapCollection",
-      "declKind": "Struct",
-      "usr": "s:s17LazyMapCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base, Element where Base : Collection>",
-      "conformingProtocols": [
-        "Sequence",
-        "LazyCollectionProtocol",
-        "Collection",
-        "LazySequenceProtocol",
-        "BidirectionalCollection",
-        "RandomAccessCollection"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s17LazyMapCollectionV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -70122,20 +79402,16 @@
               "printedName": "LazyMapSequence<Base, Element>.Iterator",
               "usr": "s:s15LazyMapSequenceV8IteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s17LazyMapCollectionV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Collection>"
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s17LazyMapCollectionV12makeIterators0aB8SequenceV0E0Vyxq__GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -70150,19 +79426,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17LazyMapCollectionV12makeIterators0aB8SequenceV0E0Vyxq__GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s17LazyMapCollectionV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -70174,11 +79450,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17LazyMapCollectionV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -70186,59 +79457,61 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Base, Element where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s17LazyMapCollectionV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Index"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s17LazyMapCollectionV5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s17LazyMapCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Indices"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s17LazyMapCollectionV7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s17LazyMapCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyMapCollection",
               "printedName": "LazyMapCollection<Base.SubSequence, Element>",
-              "usr": "s:s17LazyMapCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -70250,21 +79523,19 @@
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s17LazyMapCollectionV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s17LazyMapCollectionV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Collection>"
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s17LazyMapCollectionV10startIndex0E0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -70275,32 +79546,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17LazyMapCollectionV10startIndex0E0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Index"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionV10startIndex0E0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base, Element where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionV10startIndex0E0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s17LazyMapCollectionV8endIndex0E0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -70311,33 +79580,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17LazyMapCollectionV8endIndex0E0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Index"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionV8endIndex0E0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base, Element where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionV8endIndex0E0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s17LazyMapCollectionV5index5after5IndexQzAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -70363,20 +79629,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17LazyMapCollectionV5index5after5IndexQzAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s17LazyMapCollectionV9formIndex5aftery0E0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -70395,19 +79660,95 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17LazyMapCollectionV9formIndex5aftery0E0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Base.Index"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s17LazyMapCollectionVyq_5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "SubSequence",
+              "printedName": "LazyMapCollection<Base, Element>.SubSequence",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "LazyMapCollection",
+                  "printedName": "LazyMapCollection<τ_0_0.SubSequence, τ_0_1>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.SubSequence"
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_1"
+                    }
+                  ],
+                  "usr": "s:s17LazyMapCollectionV"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Base.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "Base.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s17LazyMapCollectionVyABy11SubSequenceQzq_GSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:s17LazyMapCollectionV7indices7IndicesQzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -70418,32 +79759,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17LazyMapCollectionV7indices7IndicesQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Indices"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionV7indices7IndicesQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base, Element where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionV7indices7IndicesQzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "isEmpty",
           "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:s17LazyMapCollectionV7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -70455,11 +79794,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17LazyMapCollectionV7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -70467,21 +79801,24 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionV7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base, Element where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionV7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s17LazyMapCollectionV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -70493,11 +79830,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17LazyMapCollectionV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -70505,74 +79837,74 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Base, Element where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "first",
           "printedName": "first",
-          "declKind": "Var",
-          "usr": "s:s17LazyMapCollectionV5firstq_Sgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17LazyMapCollectionV5firstq_Sgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionV5firstq_Sgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base, Element where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionV5firstq_Sgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s17LazyMapCollectionV5index_8offsetBy5IndexQzAF_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -70604,26 +79936,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17LazyMapCollectionV5index_8offsetBy5IndexQzAF_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s17LazyMapCollectionV5index_8offsetBy07limitedF05IndexQzSgAG_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "LazyMapCollection<Base, Element>.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -70637,7 +79967,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -70669,20 +80000,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17LazyMapCollectionV5index_8offsetBy07limitedF05IndexQzSgAG_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s17LazyMapCollectionV8distance4from2toSi5IndexQz_AGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -70714,23 +80044,24 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17LazyMapCollectionV8distance4from2toSi5IndexQz_AGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Elements",
           "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s17LazyMapCollectionV8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyMapCollection",
               "printedName": "LazyMapCollection<Base, Element>",
-              "usr": "s:s17LazyMapCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -70742,39 +80073,37 @@
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s17LazyMapCollectionV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s17LazyMapCollectionV8Elementsa",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Collection>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s17LazyMapCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s17LazyMapCollectionV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : Collection>",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s17LazyMapCollectionVsSKRzrlE5index6before5IndexQzAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -70800,20 +80129,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17LazyMapCollectionVsSKRzrlE5index6before5IndexQzAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:s17LazyMapCollectionVsSKRzrlE9formIndex6beforey0E0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, Element where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -70832,87 +80160,91 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s17LazyMapCollectionVsSKRzrlE9formIndex6beforey0E0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base, Element where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "last",
           "printedName": "last",
-          "declKind": "Var",
-          "usr": "s:s17LazyMapCollectionVsSKRzrlE4lastq_Sgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17LazyMapCollectionVsSKRzrlE4lastq_Sgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base, Element where Base : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17LazyMapCollectionVsSKRzrlE4lastq_Sgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base, Element where Base : BidirectionalCollection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s17LazyMapCollectionVsSKRzrlE4lastq_Sgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s17LazyMapCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<Base, Element where Base : Collection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "LazyCollectionProtocol",
+        "Collection",
+        "LazySequenceProtocol",
+        "BidirectionalCollection",
+        "RandomAccessCollection"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "MemoryLayout",
       "printedName": "MemoryLayout",
-      "declKind": "Enum",
-      "usr": "s:s12MemoryLayoutO",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "declAttributes": [
-        "Frozen"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "size",
           "printedName": "size",
-          "declKind": "Var",
-          "usr": "s:s12MemoryLayoutO4sizeSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -70924,12 +80256,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12MemoryLayoutO4sizeSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<T>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -70937,22 +80263,26 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12MemoryLayoutO4sizeSivgZ",
+              "moduleName": "Swift",
+              "genericSig": "<T>",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12MemoryLayoutO4sizeSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "stride",
           "printedName": "stride",
-          "declKind": "Var",
-          "usr": "s:s12MemoryLayoutO6strideSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -70964,12 +80294,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12MemoryLayoutO6strideSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<T>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -70977,22 +80301,26 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12MemoryLayoutO6strideSivgZ",
+              "moduleName": "Swift",
+              "genericSig": "<T>",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12MemoryLayoutO6strideSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "alignment",
           "printedName": "alignment",
-          "declKind": "Var",
-          "usr": "s:s12MemoryLayoutO9alignmentSivpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -71004,12 +80332,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12MemoryLayoutO9alignmentSivgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<T>",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -71017,23 +80339,26 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12MemoryLayoutO9alignmentSivgZ",
+              "moduleName": "Swift",
+              "genericSig": "<T>",
+              "static": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12MemoryLayoutO9alignmentSivpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "size",
           "printedName": "size(ofValue:)",
-          "declKind": "Func",
-          "usr": "s:s12MemoryLayoutO4size7ofValueSix_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -71046,21 +80371,20 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s12MemoryLayoutO4size7ofValueSix_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "stride",
           "printedName": "stride(ofValue:)",
-          "declKind": "Func",
-          "usr": "s:s12MemoryLayoutO6stride7ofValueSix_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -71073,21 +80397,20 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s12MemoryLayoutO6stride7ofValueSix_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "alignment",
           "printedName": "alignment(ofValue:)",
-          "declKind": "Func",
-          "usr": "s:s12MemoryLayoutO9alignment7ofValueSix_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -71100,27 +80423,25 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s12MemoryLayoutO9alignment7ofValueSix_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "offset",
           "printedName": "offset(of:)",
-          "declKind": "Func",
-          "usr": "s:s12MemoryLayoutO6offset2ofSiSgs14PartialKeyPathCyxG_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -71128,53 +80449,142 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "PartialKeyPath",
               "printedName": "PartialKeyPath<T>",
-              "usr": "s:s14PartialKeyPathC",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:s14PartialKeyPathC"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s12MemoryLayoutO6offset2ofSiSgs14PartialKeyPathCyxG_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s12MemoryLayoutO",
+      "moduleName": "Swift",
+      "genericSig": "<T>",
+      "declAttributes": [
+        "Frozen"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "MutableCollection",
       "printedName": "MutableCollection",
-      "declKind": "Protocol",
-      "usr": "s:SM",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Collection, Self.SubSequence : MutableCollection>",
-      "conformingProtocols": [
-        "Collection",
-        "Sequence"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Element",
+          "printedName": "Element",
+          "declKind": "AssociatedType",
+          "usr": "s:SM7ElementQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Index",
+          "printedName": "Index",
+          "declKind": "AssociatedType",
+          "usr": "s:SM5IndexQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "declKind": "AssociatedType",
+          "usr": "s:SM11SubSequenceQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Index"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SMy7ElementQz5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : MutableCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.SubSequence"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Self.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "Self.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SMy11SubSequenceQzSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : MutableCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ],
+          "hasSetter": true
+        },
+        {
           "kind": "Function",
           "name": "partition",
           "printedName": "partition(by:)",
-          "declKind": "Func",
-          "usr": "s:SM9partition2by5IndexQzSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : MutableCollection>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -71185,9 +80595,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -71207,20 +80614,27 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SM9partition2by5IndexQzSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : MutableCollection>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "swapAt",
           "printedName": "swapAt(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SM6swapAtyy5IndexQz_ACtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : MutableCollection>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -71237,74 +80651,18 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "partition",
-          "printedName": "partition(by:)",
+          ],
           "declKind": "Func",
-          "usr": "s:SMsE9partition2by5IndexQzSb7ElementQzKXE_tKF",
-          "location": "",
+          "usr": "s:SM6swapAtyy5IndexQz_ACtF",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : MutableCollection>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.Index"
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "partition",
           "printedName": "partition(by:)",
-          "declKind": "Func",
-          "usr": "s:SMsSKRzrlE9partition2by5IndexSlQzSb7ElementSTQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self : MutableCollection>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -71315,9 +80673,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -71337,23 +80692,77 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SMsE9partition2by5IndexQzSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : MutableCollection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "partition",
+          "printedName": "partition(by:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Index"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(Self.Element) throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Paren",
+                  "printedName": "(Self.Element)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "Self.Element"
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SMsSKRzrlE9partition2by5IndexSlQzSb7ElementSTQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection, Self : MutableCollection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "shuffle",
           "printedName": "shuffle(using:)",
-          "declKind": "Func",
-          "usr": "s:SMsSkRzrlE7shuffle5usingyqd__z_tSGRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : MutableCollection, Self : RandomAccessCollection, T : RandomNumberGenerator>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -71365,42 +80774,81 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SMsSkRzrlE7shuffle5usingyqd__z_tSGRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : MutableCollection, Self : RandomAccessCollection, T : RandomNumberGenerator>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "shuffle",
           "printedName": "shuffle()",
-          "declKind": "Func",
-          "usr": "s:SMsSkRzrlE7shuffleyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : MutableCollection, Self : RandomAccessCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SMsSkRzrlE7shuffleyyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : MutableCollection, Self : RandomAccessCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<Self>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Self.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "Self.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SMsEys5SliceVyxGSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : MutableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
         },
         {
           "kind": "Function",
           "name": "swapAt",
           "printedName": "swapAt(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SMsE6swapAtyy5IndexQz_ACtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : MutableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -71417,65 +80865,134 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SMsE6swapAtyy5IndexQz_ACtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : MutableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.SubSequence"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "R"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SMsEy11SubSequenceQzqd__cSXRd__5BoundQyd__5IndexRtzluip",
+          "moduleName": "Swift",
+          "genericSig": "<Self, R where Self : MutableCollection, R : RangeExpression, Self.Index == R.Bound>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.SubSequence"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(UnboundedRange_) -> ()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Void",
+                  "printedName": "()"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Paren",
+                  "printedName": "(UnboundedRange_)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnboundedRange_",
+                      "printedName": "UnboundedRange_",
+                      "usr": "s:s15UnboundedRange_O"
+                    }
+                  ],
+                  "usr": "s:s15UnboundedRange_O"
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SMsEy11SubSequenceQzys15UnboundedRange_OXEcip",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : MutableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
         },
         {
           "kind": "Function",
           "name": "reverse",
           "printedName": "reverse()",
-          "declKind": "Func",
-          "usr": "s:SMsSKRzrlE7reverseyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self : MutableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SMsSKRzrlE7reverseyyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection, Self : MutableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "sort",
           "printedName": "sort()",
-          "declKind": "Func",
-          "usr": "s:SMsSkRzSL7ElementSTRpzrlE4sortyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : MutableCollection, Self : RandomAccessCollection, Self.Element : Comparable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SMsSkRzSL7ElementSTRpzrlE4sortyyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : MutableCollection, Self : RandomAccessCollection, Self.Element : Comparable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "sort",
           "printedName": "sort(by:)",
-          "declKind": "Func",
-          "usr": "s:SMsSkRzrlE4sort2byySb7ElementSTQz_ADtKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : MutableCollection, Self : RandomAccessCollection>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -71486,9 +81003,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element, Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -71513,24 +81027,37 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SMsSkRzrlE4sort2byySb7ElementSTQz_ADtKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : MutableCollection, Self : RandomAccessCollection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SM",
+      "moduleName": "Swift",
+      "genericSig": "<Self : Collection, Self.SubSequence : MutableCollection>",
+      "conformingProtocols": [
+        "Collection",
+        "Sequence"
       ]
     },
     {
       "kind": "Function",
       "name": "swap",
       "printedName": "swap(_:_:)",
-      "declKind": "Func",
-      "usr": "s:s4swapyyxz_xztlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -71547,37 +81074,24 @@
           "name": "GenericTypeParam",
           "printedName": "T"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s4swapyyxz_xztlF",
+      "moduleName": "Swift",
+      "genericSig": "<T>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "ObjectIdentifier",
       "printedName": "ObjectIdentifier",
-      "declKind": "Struct",
-      "usr": "s:SO",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "CustomDebugStringConvertible",
-        "Equatable",
-        "Comparable",
-        "Hashable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SOySOyXlcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -71597,19 +81111,18 @@
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SOySOyXlcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SOySOypXpcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -71629,16 +81142,18 @@
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SOySOypXpcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:SO16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -71650,10 +81165,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SO16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -71661,21 +81172,84 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SO16debugDescriptionSSvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SO16debugDescriptionSSvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ObjectIdentifier",
+              "printedName": "ObjectIdentifier",
+              "usr": "s:SO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ObjectIdentifier",
+              "printedName": "ObjectIdentifier",
+              "usr": "s:SO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SO2eeoiySbSO_SOtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ObjectIdentifier",
+              "printedName": "ObjectIdentifier",
+              "usr": "s:SO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ObjectIdentifier",
+              "printedName": "ObjectIdentifier",
+              "usr": "s:SO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SO1loiySbSO_SOtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SO4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -71688,16 +81262,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SO4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SO9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -71709,10 +81285,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SO9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -71720,43 +81292,41 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SO9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SO9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:SO",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "CustomDebugStringConvertible",
+        "Equatable",
+        "Comparable",
+        "Hashable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Optional",
       "printedName": "Optional",
-      "declKind": "Enum",
-      "usr": "s:Sq",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Wrapped>",
-      "conformingProtocols": [
-        "ExpressibleByNilLiteral",
-        "Encodable",
-        "Decodable",
-        "CustomDebugStringConvertible",
-        "CustomReflectable",
-        "Equatable",
-        "Hashable",
-        "_ObjectiveCBridgeable"
-      ],
-      "declAttributes": [
-        "Frozen"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "none",
           "printedName": "none",
-          "declKind": "EnumElement",
-          "usr": "s:Sq4noneyxSgABmlF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -71767,14 +81337,14 @@
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Optional<Wrapped>",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Wrapped"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -71790,14 +81360,14 @@
                           "kind": "TypeNominal",
                           "name": "Optional",
                           "printedName": "Optional<Wrapped>",
-                          "usr": "s:Sq",
                           "children": [
                             {
                               "kind": "TypeNominal",
                               "name": "GenericTypeParam",
                               "printedName": "Wrapped"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         }
                       ]
                     }
@@ -71805,16 +81375,16 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:Sq4noneyxSgABmlF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0
         },
         {
           "kind": "Var",
           "name": "some",
           "printedName": "some",
-          "declKind": "EnumElement",
-          "usr": "s:Sq4someyxSgxcABmlF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -71830,14 +81400,14 @@
                       "kind": "TypeNominal",
                       "name": "Optional",
                       "printedName": "Optional<Wrapped>",
-                      "usr": "s:Sq",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
                           "printedName": "Wrapped"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     },
                     {
                       "kind": "TypeNominal",
@@ -71867,14 +81437,14 @@
                           "kind": "TypeNominal",
                           "name": "Optional",
                           "printedName": "Optional<Wrapped>",
-                          "usr": "s:Sq",
                           "children": [
                             {
                               "kind": "TypeNominal",
                               "name": "GenericTypeParam",
                               "printedName": "Wrapped"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         }
                       ]
                     }
@@ -71882,76 +81452,66 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:Sq4someyxSgxcABmlF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SqyxSgxcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Wrapped>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Optional<Wrapped>",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Wrapped"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Wrapped"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SqyxSgxcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Wrapped>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:Sq3mapyqd__Sgqd__xKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Wrapped, U>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "U?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "U"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Wrapped) throws -> U",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -71970,58 +81530,57 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sq3mapyqd__Sgqd__xKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Wrapped, U>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "flatMap",
           "printedName": "flatMap(_:)",
-          "declKind": "Func",
-          "usr": "s:Sq7flatMapyqd__SgABxKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Wrapped, U>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "U?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "U"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Wrapped) throws -> U?",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "U?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "U"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -72035,54 +81594,58 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sq7flatMapyqd__SgABxKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Wrapped, U>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(nilLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Sq10nilLiteralxSgyt_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Wrapped>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Optional<Wrapped>",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Wrapped"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sq10nilLiteralxSgyt_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Wrapped>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "unsafelyUnwrapped",
           "printedName": "unsafelyUnwrapped",
-          "declKind": "Var",
-          "usr": "s:Sq17unsafelyUnwrappedxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -72093,37 +81656,33 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sq17unsafelyUnwrappedxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Wrapped>",
-              "declAttributes": [
-                "Inline"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Wrapped"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sq17unsafelyUnwrappedxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Wrapped>",
+              "declAttributes": [
+                "Inline"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sq17unsafelyUnwrappedxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:SqsSERzlE6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Wrapped where Wrapped : Encodable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -72136,34 +81695,30 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SqsSERzlE6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Wrapped where Wrapped : Encodable>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:SqsSeRzlE4fromxSgs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Wrapped where Wrapped : Decodable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Optional<Wrapped>",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Wrapped"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -72171,16 +81726,17 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SqsSeRzlE4fromxSgs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Wrapped where Wrapped : Decodable>",
+          "throwing": true
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Sq16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -72192,11 +81748,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sq16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Wrapped>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -72204,18 +81755,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sq16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Wrapped>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sq16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Sq12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -72227,11 +81781,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sq12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Wrapped>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -72239,22 +81788,68 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sq12customMirrors0B0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Wrapped>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sq12customMirrors0B0Vvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Wrapped?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Wrapped"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Wrapped?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Wrapped"
+                }
+              ],
+              "usr": "s:Sq"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SqsSQRzlE2eeoiySbxSg_ABtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Wrapped where Wrapped : Equatable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SqsSHRzlE4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Wrapped where Wrapped : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -72267,16 +81862,19 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SqsSHRzlE4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Wrapped where Wrapped : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SqsSHRzlE9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -72288,11 +81886,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SqsSHRzlE9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Wrapped where Wrapped : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -72300,37 +81893,388 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SqsSHRzlE9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Wrapped where Wrapped : Hashable>",
+              "implicit": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SqsSHRzlE9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Function",
+          "name": "~=",
+          "printedName": "~=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "_OptionalNilComparisonType",
+              "printedName": "_OptionalNilComparisonType",
+              "usr": "s:s26_OptionalNilComparisonTypeV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Wrapped?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Wrapped"
+                }
+              ],
+              "usr": "s:Sq"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sq2teoiySbs26_OptionalNilComparisonTypeV_xSgtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Wrapped>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Wrapped?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Wrapped"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "_OptionalNilComparisonType",
+              "printedName": "_OptionalNilComparisonType",
+              "usr": "s:s26_OptionalNilComparisonTypeV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sq2eeoiySbxSg_s26_OptionalNilComparisonTypeVtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Wrapped>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "!=",
+          "printedName": "!=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Wrapped?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Wrapped"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "_OptionalNilComparisonType",
+              "printedName": "_OptionalNilComparisonType",
+              "usr": "s:s26_OptionalNilComparisonTypeV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sq2neoiySbxSg_s26_OptionalNilComparisonTypeVtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Wrapped>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "_OptionalNilComparisonType",
+              "printedName": "_OptionalNilComparisonType",
+              "usr": "s:s26_OptionalNilComparisonTypeV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Wrapped?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Wrapped"
+                }
+              ],
+              "usr": "s:Sq"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sq2eeoiySbs26_OptionalNilComparisonTypeV_xSgtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Wrapped>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "!=",
+          "printedName": "!=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "_OptionalNilComparisonType",
+              "printedName": "_OptionalNilComparisonType",
+              "usr": "s:s26_OptionalNilComparisonTypeV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Wrapped?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Wrapped"
+                }
+              ],
+              "usr": "s:Sq"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sq2neoiySbs26_OptionalNilComparisonTypeV_xSgtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Wrapped>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:Sq",
+      "moduleName": "Swift",
+      "genericSig": "<Wrapped>",
+      "declAttributes": [
+        "Frozen"
+      ],
+      "conformingProtocols": [
+        "ExpressibleByNilLiteral",
+        "Encodable",
+        "Decodable",
+        "CustomDebugStringConvertible",
+        "CustomReflectable",
+        "Equatable",
+        "Hashable",
+        "_ObjectiveCBridgeable"
       ]
     },
     {
+      "kind": "Function",
+      "name": "??",
+      "printedName": "??(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "T"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "T?",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "T"
+            }
+          ],
+          "usr": "s:Sq"
+        },
+        {
+          "kind": "TypeFunc",
+          "name": "Function",
+          "printedName": "() throws -> T",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "T"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "typeAttributes": [
+            "noescape"
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2qqoiyxxSg_xyKXKtKlF",
+      "moduleName": "Swift",
+      "genericSig": "<T>",
+      "declAttributes": [
+        "Rethrows",
+        "Transparent"
+      ],
+      "throwing": true
+    },
+    {
+      "kind": "Function",
+      "name": "??",
+      "printedName": "??(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "T?",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "T"
+            }
+          ],
+          "usr": "s:Sq"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Optional",
+          "printedName": "T?",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "T"
+            }
+          ],
+          "usr": "s:Sq"
+        },
+        {
+          "kind": "TypeFunc",
+          "name": "Function",
+          "printedName": "() throws -> T?",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "T?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "T"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            }
+          ],
+          "typeAttributes": [
+            "noescape"
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2qqoiyxSgAB_AByKXKtKlF",
+      "moduleName": "Swift",
+      "genericSig": "<T>",
+      "declAttributes": [
+        "Rethrows",
+        "Transparent"
+      ],
+      "throwing": true
+    },
+    {
       "kind": "TypeDecl",
       "name": "OptionSet",
       "printedName": "OptionSet",
-      "declKind": "Protocol",
-      "usr": "s:s9OptionSetP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : RawRepresentable, Self : SetAlgebra>",
-      "conformingProtocols": [
-        "SetAlgebra",
-        "RawRepresentable",
-        "Equatable",
-        "ExpressibleByArrayLiteral"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Element",
+          "printedName": "Element",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:s9OptionSetP7ElementQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(rawValue:)",
-          "declKind": "Constructor",
-          "usr": "s:s9OptionSetP8rawValuex03RawD0Qz_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -72342,20 +82286,17 @@
               "name": "DependentMember",
               "printedName": "Self.RawValue"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s9OptionSetP8rawValuex03RawD0Qz_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : OptionSet>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "union",
           "printedName": "union(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPsE5unionyxxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -72367,20 +82308,19 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPsE5unionyxxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : OptionSet>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "intersection",
           "printedName": "intersection(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPsE12intersectionyxxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -72392,20 +82332,19 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPsE12intersectionyxxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : OptionSet>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "symmetricDifference",
           "printedName": "symmetricDifference(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPsE19symmetricDifferenceyxxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -72417,20 +82356,19 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPsE19symmetricDifferenceyxxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : OptionSet>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPs7ElementQzRszrlE8containsySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet, Self == Self.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -72443,22 +82381,19 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPs7ElementQzRszrlE8containsySbxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : OptionSet, Self == Self.Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPs7ElementQzRszrlE6insertySb8inserted_x17memberAfterInserttxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet, Self == Self.Element>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -72483,111 +82418,108 @@
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPs7ElementQzRszrlE6insertySb8inserted_x17memberAfterInserttxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : OptionSet, Self == Self.Element>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "remove",
           "printedName": "remove(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPs7ElementQzRszrlE6removeyxSgxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet, Self == Self.Element>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPs7ElementQzRszrlE6removeyxSgxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : OptionSet, Self == Self.Element>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "update",
           "printedName": "update(with:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPs7ElementQzRszrlE6update4withxSgx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet, Self == Self.Element>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPs7ElementQzRszrlE6update4withxSgx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : OptionSet, Self == Self.Element>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s9OptionSetPss17FixedWidthInteger8RawValueRpzrlExycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet, Self.RawValue : FixedWidthInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s9OptionSetPss17FixedWidthInteger8RawValueRpzrlExycfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : OptionSet, Self.RawValue : FixedWidthInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formUnion",
           "printedName": "formUnion(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPss17FixedWidthInteger8RawValueRpzrlE9formUnionyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet, Self.RawValue : FixedWidthInteger>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -72599,21 +82531,20 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPss17FixedWidthInteger8RawValueRpzrlE9formUnionyyxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : OptionSet, Self.RawValue : FixedWidthInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "formIntersection",
           "printedName": "formIntersection(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPss17FixedWidthInteger8RawValueRpzrlE16formIntersectionyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet, Self.RawValue : FixedWidthInteger>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -72625,21 +82556,20 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPss17FixedWidthInteger8RawValueRpzrlE16formIntersectionyyxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : OptionSet, Self.RawValue : FixedWidthInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "formSymmetricDifference",
           "printedName": "formSymmetricDifference(_:)",
-          "declKind": "Func",
-          "usr": "s:s9OptionSetPss17FixedWidthInteger8RawValueRpzrlE23formSymmetricDifferenceyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : OptionSet, Self.RawValue : FixedWidthInteger>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -72651,29 +82581,37 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s9OptionSetPss17FixedWidthInteger8RawValueRpzrlE23formSymmetricDifferenceyyxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : OptionSet, Self.RawValue : FixedWidthInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s9OptionSetP",
+      "moduleName": "Swift",
+      "genericSig": "<Self : RawRepresentable, Self : SetAlgebra>",
+      "conformingProtocols": [
+        "SetAlgebra",
+        "RawRepresentable",
+        "Equatable",
+        "ExpressibleByArrayLiteral"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "TextOutputStream",
       "printedName": "TextOutputStream",
-      "declKind": "Protocol",
-      "usr": "s:s16TextOutputStreamP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Function",
           "name": "write",
           "printedName": "write(_:)",
-          "declKind": "Func",
-          "usr": "s:s16TextOutputStreamP5writeyySSF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : TextOutputStream>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -72686,28 +82624,28 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16TextOutputStreamP5writeyySSF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : TextOutputStream>",
+          "protocolReq": true,
+          "mutating": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s16TextOutputStreamP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "TextOutputStreamable",
       "printedName": "TextOutputStreamable",
-      "declKind": "Protocol",
-      "usr": "s:s20TextOutputStreamableP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Function",
           "name": "write",
           "printedName": "write(to:)",
-          "declKind": "Func",
-          "usr": "s:s20TextOutputStreamableP5write2toyqd__z_ts0aB6StreamRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Target where Self : TextOutputStreamable, Target : TextOutputStream>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -72719,27 +82657,27 @@
               "name": "GenericTypeParam",
               "printedName": "Target"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s20TextOutputStreamableP5write2toyqd__z_ts0aB6StreamRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Target where Self : TextOutputStreamable, Target : TextOutputStream>",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s20TextOutputStreamableP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "CustomStringConvertible",
       "printedName": "CustomStringConvertible",
-      "declKind": "Protocol",
-      "usr": "s:s23CustomStringConvertibleP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:s23CustomStringConvertibleP11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -72751,11 +82689,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s23CustomStringConvertibleP11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CustomStringConvertible>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -72763,47 +82696,45 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s23CustomStringConvertibleP11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : CustomStringConvertible>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s23CustomStringConvertibleP11descriptionSSvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s23CustomStringConvertibleP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "LosslessStringConvertible",
       "printedName": "LosslessStringConvertible",
-      "declKind": "Protocol",
-      "usr": "s:s25LosslessStringConvertibleP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : CustomStringConvertible>",
-      "conformingProtocols": [
-        "CustomStringConvertible"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s25LosslessStringConvertiblePyxSgSScfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : LosslessStringConvertible>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -72811,27 +82742,31 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s25LosslessStringConvertiblePyxSgSScfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : LosslessStringConvertible>",
+          "protocolReq": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s25LosslessStringConvertibleP",
+      "moduleName": "Swift",
+      "genericSig": "<Self : CustomStringConvertible>",
+      "conformingProtocols": [
+        "CustomStringConvertible"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "CustomDebugStringConvertible",
       "printedName": "CustomDebugStringConvertible",
-      "declKind": "Protocol",
-      "usr": "s:s28CustomDebugStringConvertibleP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s28CustomDebugStringConvertibleP16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -72843,11 +82778,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s28CustomDebugStringConvertibleP16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CustomDebugStringConvertible>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -72855,38 +82785,94 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s28CustomDebugStringConvertibleP16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : CustomDebugStringConvertible>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s28CustomDebugStringConvertibleP16debugDescriptionSSvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s28CustomDebugStringConvertibleP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "Never",
       "printedName": "Never",
-      "declKind": "Enum",
-      "usr": "s:s5NeverO",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Error",
-        "Equatable",
-        "Comparable",
-        "Hashable"
-      ],
-      "declAttributes": [
-        "Frozen"
-      ],
       "children": [
         {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Never",
+              "printedName": "Never",
+              "usr": "s:s5NeverO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Never",
+              "printedName": "Never",
+              "usr": "s:s5NeverO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5NeverO2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "implicit": true,
+          "declAttributes": [
+            "Infix"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Never",
+              "printedName": "Never",
+              "usr": "s:s5NeverO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Never",
+              "printedName": "Never",
+              "usr": "s:s5NeverO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5NeverO1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true
+        },
+        {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:s5NeverO9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -72898,10 +82884,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5NeverO9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -72909,18 +82891,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5NeverO9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5NeverO9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:s5NeverO4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -72933,34 +82919,45 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5NeverO4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "implicit": true
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s5NeverO",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Frozen"
+      ],
+      "conformingProtocols": [
+        "Error",
+        "Equatable",
+        "Comparable",
+        "Hashable"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "Void",
       "printedName": "Void",
-      "declKind": "TypeAlias",
-      "usr": "s:s4Voida",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Void",
           "printedName": "()"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s4Voida",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "Float32",
       "printedName": "Float32",
-      "declKind": "TypeAlias",
-      "usr": "s:s7Float32a",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -72968,16 +82965,15 @@
           "printedName": "Float",
           "usr": "s:Sf"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s7Float32a",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "Float64",
       "printedName": "Float64",
-      "declKind": "TypeAlias",
-      "usr": "s:s7Float64a",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -72985,16 +82981,15 @@
           "printedName": "Double",
           "usr": "s:Sd"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s7Float64a",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "IntegerLiteralType",
       "printedName": "IntegerLiteralType",
-      "declKind": "TypeAlias",
-      "usr": "s:s18IntegerLiteralTypea",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -73002,16 +82997,15 @@
           "printedName": "Int",
           "usr": "s:Si"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s18IntegerLiteralTypea",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "FloatLiteralType",
       "printedName": "FloatLiteralType",
-      "declKind": "TypeAlias",
-      "usr": "s:s16FloatLiteralTypea",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -73019,16 +83013,15 @@
           "printedName": "Double",
           "usr": "s:Sd"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s16FloatLiteralTypea",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "BooleanLiteralType",
       "printedName": "BooleanLiteralType",
-      "declKind": "TypeAlias",
-      "usr": "s:s18BooleanLiteralTypea",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -73036,16 +83029,15 @@
           "printedName": "Bool",
           "usr": "s:Sb"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s18BooleanLiteralTypea",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "UnicodeScalarType",
       "printedName": "UnicodeScalarType",
-      "declKind": "TypeAlias",
-      "usr": "s:s17UnicodeScalarTypea",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -73053,16 +83045,15 @@
           "printedName": "String",
           "usr": "s:SS"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s17UnicodeScalarTypea",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "ExtendedGraphemeClusterType",
       "printedName": "ExtendedGraphemeClusterType",
-      "declKind": "TypeAlias",
-      "usr": "s:s27ExtendedGraphemeClusterTypea",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -73070,16 +83061,15 @@
           "printedName": "String",
           "usr": "s:SS"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s27ExtendedGraphemeClusterTypea",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "StringLiteralType",
       "printedName": "StringLiteralType",
-      "declKind": "TypeAlias",
-      "usr": "s:s17StringLiteralTypea",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -73087,16 +83077,15 @@
           "printedName": "String",
           "usr": "s:SS"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s17StringLiteralTypea",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "AnyObject",
       "printedName": "AnyObject",
-      "declKind": "TypeAlias",
-      "usr": "s:s9AnyObjecta",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNameAlias",
@@ -73110,16 +83099,15 @@
             }
           ]
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s9AnyObjecta",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "AnyClass",
       "printedName": "AnyClass",
-      "declKind": "TypeAlias",
-      "usr": "s:s8AnyClassa",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -73140,95 +83128,652 @@
             }
           ]
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s8AnyClassa",
+      "moduleName": "Swift"
+    },
+    {
+      "kind": "Function",
+      "name": "~=",
+      "printedName": "~=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "T"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "T"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2teoiySbx_xtSQRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : Equatable>",
+      "declAttributes": [
+        "Transparent"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "++",
+      "printedName": "++",
+      "declKind": "PostfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Postfix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "--",
+      "printedName": "--",
+      "declKind": "PostfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Postfix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "...",
+      "printedName": "...",
+      "declKind": "PostfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Postfix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "++",
+      "printedName": "++",
+      "declKind": "PrefixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Prefix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "--",
+      "printedName": "--",
+      "declKind": "PrefixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Prefix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "!",
+      "printedName": "!",
+      "declKind": "PrefixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Prefix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "~",
+      "printedName": "~",
+      "declKind": "PrefixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Prefix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "+",
+      "printedName": "+",
+      "declKind": "PrefixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Prefix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "-",
+      "printedName": "-",
+      "declKind": "PrefixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Prefix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "...",
+      "printedName": "...",
+      "declKind": "PrefixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Prefix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "..<",
+      "printedName": "..<",
+      "declKind": "PrefixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Prefix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "<<",
+      "printedName": "<<",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&<<",
+      "printedName": "&<<",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": ">>",
+      "printedName": ">>",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&>>",
+      "printedName": "&>>",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "*",
+      "printedName": "*",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&*",
+      "printedName": "&*",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "\/",
+      "printedName": "\/",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "%",
+      "printedName": "%",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&",
+      "printedName": "&",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "+",
+      "printedName": "+",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&+",
+      "printedName": "&+",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "-",
+      "printedName": "-",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&-",
+      "printedName": "&-",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "|",
+      "printedName": "|",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "^",
+      "printedName": "^",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "...",
+      "printedName": "...",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "..<",
+      "printedName": "..<",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "??",
+      "printedName": "??",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "<",
+      "printedName": "<",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "<=",
+      "printedName": "<=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": ">",
+      "printedName": ">",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": ">=",
+      "printedName": ">=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "==",
+      "printedName": "==",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "!=",
+      "printedName": "!=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "===",
+      "printedName": "===",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "!==",
+      "printedName": "!==",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "~=",
+      "printedName": "~=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&&",
+      "printedName": "&&",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "||",
+      "printedName": "||",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "*=",
+      "printedName": "*=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&*=",
+      "printedName": "&*=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "\/=",
+      "printedName": "\/=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "%=",
+      "printedName": "%=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "+=",
+      "printedName": "+=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&+=",
+      "printedName": "&+=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "-=",
+      "printedName": "-=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&-=",
+      "printedName": "&-=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "<<=",
+      "printedName": "<<=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&<<=",
+      "printedName": "&<<=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": ">>=",
+      "printedName": ">>=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&>>=",
+      "printedName": "&>>=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "&=",
+      "printedName": "&=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "^=",
+      "printedName": "^=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "|=",
+      "printedName": "|=",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
+      "kind": "OperatorDecl",
+      "name": "~>",
+      "printedName": "~>",
+      "declKind": "InfixOperator",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Infix"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "LazyPrefixWhileSequence",
       "printedName": "LazyPrefixWhileSequence",
-      "declKind": "Struct",
-      "usr": "s:s23LazyPrefixWhileSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Sequence>",
-      "conformingProtocols": [
-        "Sequence",
-        "LazySequenceProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s23LazyPrefixWhileSequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s23LazyPrefixWhileSequenceV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>"
         },
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "conformingProtocols": [
-            "IteratorProtocol",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Element"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV7Elementa",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence>"
             },
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV4next7ElementQzSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "LazyPrefixWhileSequence<Base>.Iterator.Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -73242,19 +83787,23 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV4next7ElementQzSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorVACa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -73262,72 +83811,79 @@
                   "printedName": "LazyPrefixWhileSequence<Base>.Iterator",
                   "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorVACa",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence>",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV03SubD0a",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnySequence",
                   "printedName": "AnySequence<Base.Element>",
-                  "usr": "s:s11AnySequenceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Base.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s11AnySequenceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV03SubD0a",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Sequence>",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "Sequence"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s23LazyPrefixWhileSequenceV03SubD0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Base.Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s23LazyPrefixWhileSequenceV03SubD0a",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>"
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s23LazyPrefixWhileSequenceV12makeIteratorAB0F0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -73335,114 +83891,109 @@
               "printedName": "LazyPrefixWhileSequence<Base>.Iterator",
               "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s23LazyPrefixWhileSequenceV12makeIteratorAB0F0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Elements",
           "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s23LazyPrefixWhileSequenceV8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyPrefixWhileSequence",
               "printedName": "LazyPrefixWhileSequence<Base>",
-              "usr": "s:s23LazyPrefixWhileSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "usr": "s:s23LazyPrefixWhileSequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s23LazyPrefixWhileSequenceV8Elementsa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Sequence>"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s23LazyPrefixWhileSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<Base where Base : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "LazySequenceProtocol"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "LazyPrefixWhileCollection",
       "printedName": "LazyPrefixWhileCollection",
-      "declKind": "Struct",
-      "usr": "s:s25LazyPrefixWhileCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Collection>",
-      "conformingProtocols": [
-        "Sequence",
-        "Collection",
-        "BidirectionalCollection",
-        "LazyCollectionProtocol",
-        "LazySequenceProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s25LazyPrefixWhileCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s25LazyPrefixWhileCollectionV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s25LazyPrefixWhileCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<LazyPrefixWhileCollection<Base>>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "LazyPrefixWhileCollection",
                   "printedName": "LazyPrefixWhileCollection<Base>",
-                  "usr": "s:s25LazyPrefixWhileCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Base"
                     }
-                  ]
+                  ],
+                  "usr": "s:s25LazyPrefixWhileCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s25LazyPrefixWhileCollectionV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s25LazyPrefixWhileCollectionV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -73450,20 +84001,16 @@
               "printedName": "LazyPrefixWhileSequence<Base>.Iterator",
               "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s25LazyPrefixWhileCollectionV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s25LazyPrefixWhileCollectionV12makeIterators0abC8SequenceV0F0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -73478,38 +84025,24 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25LazyPrefixWhileCollectionV12makeIterators0abC8SequenceV0F0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "Struct",
-          "usr": "s:s25LazyPrefixWhileCollectionV5IndexV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "conformingProtocols": [
-            "Comparable",
-            "Equatable",
-            "Hashable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s25LazyPrefixWhileCollectionV5IndexVyADyx_GACQzcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -73522,20 +84055,20 @@
                   "name": "DependentMember",
                   "printedName": "Base.Index"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s25LazyPrefixWhileCollectionV5IndexVyADyx_GACQzcfc",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>",
+              "isInternal": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(endOf:)",
-              "declKind": "Constructor",
-              "usr": "s:s25LazyPrefixWhileCollectionV5IndexV5endOfADyx_Gx_tcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -73548,20 +84081,86 @@
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s25LazyPrefixWhileCollectionV5IndexV5endOfADyx_Gx_tcfc",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>",
+              "isInternal": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "LazyPrefixWhileCollection<Base>.Index",
+                  "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "LazyPrefixWhileCollection<Base>.Index",
+                  "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s25LazyPrefixWhileCollectionV5IndexV2eeoiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "LazyPrefixWhileCollection<Base>.Index",
+                  "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "LazyPrefixWhileCollection<Base>.Index",
+                  "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s25LazyPrefixWhileCollectionV5IndexV1loiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s25LazyPrefixWhileCollectionV5IndexVsSHACRpzrlE4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection, Base.Index : Hashable>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -73574,16 +84173,19 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s25LazyPrefixWhileCollectionV5IndexVsSHACRpzrlE4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection, Base.Index : Hashable>",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s25LazyPrefixWhileCollectionV5IndexVsSHACRpzrlE9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -73595,11 +84197,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s25LazyPrefixWhileCollectionV5IndexVsSHACRpzrlE9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Base where Base : Collection, Base.Index : Hashable>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -73607,23 +84204,37 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s25LazyPrefixWhileCollectionV5IndexVsSHACRpzrlE9hashValueSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Base where Base : Collection, Base.Index : Hashable>",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s25LazyPrefixWhileCollectionV5IndexVsSHACRpzrlE9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s25LazyPrefixWhileCollectionV5IndexV",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "Comparable",
+            "Equatable",
+            "Hashable"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s25LazyPrefixWhileCollectionV10startIndexAB0F0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -73635,11 +84246,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s25LazyPrefixWhileCollectionV10startIndexAB0F0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -73647,21 +84253,24 @@
                   "printedName": "LazyPrefixWhileCollection<Base>.Index",
                   "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25LazyPrefixWhileCollectionV10startIndexAB0F0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s25LazyPrefixWhileCollectionV10startIndexAB0F0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s25LazyPrefixWhileCollectionV8endIndexAB0F0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -73673,11 +84282,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s25LazyPrefixWhileCollectionV8endIndexAB0F0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -73685,22 +84289,24 @@
                   "printedName": "LazyPrefixWhileCollection<Base>.Index",
                   "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25LazyPrefixWhileCollectionV8endIndexAB0F0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s25LazyPrefixWhileCollectionV8endIndexAB0F0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s25LazyPrefixWhileCollectionV5index5afterAB5IndexVyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -73714,53 +84320,84 @@
               "printedName": "LazyPrefixWhileCollection<Base>.Index",
               "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25LazyPrefixWhileCollectionV5index5afterAB5IndexVyx_GAG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Element",
+              "printedName": "LazyPrefixWhileCollection<Base>.Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "LazyPrefixWhileCollection<Base>.Index",
+              "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s25LazyPrefixWhileCollectionVy7ElementQzAB5IndexVyx_Gcip",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s25LazyPrefixWhileCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DefaultIndices",
               "printedName": "DefaultIndices<LazyPrefixWhileCollection<Base>>",
-              "usr": "s:SI",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "LazyPrefixWhileCollection",
                   "printedName": "LazyPrefixWhileCollection<Base>",
-                  "usr": "s:s25LazyPrefixWhileCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Base"
                     }
-                  ]
+                  ],
+                  "usr": "s:s25LazyPrefixWhileCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:SI"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s25LazyPrefixWhileCollectionV7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s25LazyPrefixWhileCollectionVsSKRzrlE5index6beforeAB5IndexVyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -73774,46 +84411,59 @@
               "printedName": "LazyPrefixWhileCollection<Base>.Index",
               "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25LazyPrefixWhileCollectionVsSKRzrlE5index6beforeAB5IndexVyx_GAG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Elements",
           "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s25LazyPrefixWhileCollectionV8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazyPrefixWhileCollection",
               "printedName": "LazyPrefixWhileCollection<Base>",
-              "usr": "s:s25LazyPrefixWhileCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "usr": "s:s25LazyPrefixWhileCollectionV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s25LazyPrefixWhileCollectionV8Elementsa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s25LazyPrefixWhileCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<Base where Base : Collection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "Collection",
+        "BidirectionalCollection",
+        "LazyCollectionProtocol",
+        "LazySequenceProtocol"
       ]
     },
     {
       "kind": "Function",
       "name": "print",
       "printedName": "print(_:separator:terminator:)",
-      "declKind": "Func",
-      "usr": "s:s5print_9separator10terminatoryypd_S2StF",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Inline"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -73824,14 +84474,14 @@
           "kind": "TypeNominal",
           "name": "Array",
           "printedName": "[Any]",
-          "usr": "s:Sa",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ProtocolComposition",
               "printedName": "Any"
             }
-          ]
+          ],
+          "usr": "s:Sa"
         },
         {
           "kind": "TypeNominal",
@@ -73847,19 +84497,15 @@
           "hasDefaultArg": true,
           "usr": "s:SS"
         }
-      ]
+      ],
+      "declKind": "Func",
+      "usr": "s:s5print_9separator10terminatoryypd_S2StF",
+      "moduleName": "Swift"
     },
     {
       "kind": "Function",
       "name": "debugPrint",
       "printedName": "debugPrint(_:separator:terminator:)",
-      "declKind": "Func",
-      "usr": "s:s10debugPrint_9separator10terminatoryypd_S2StF",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Inline"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -73870,14 +84516,14 @@
           "kind": "TypeNominal",
           "name": "Array",
           "printedName": "[Any]",
-          "usr": "s:Sa",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ProtocolComposition",
               "printedName": "Any"
             }
-          ]
+          ],
+          "usr": "s:Sa"
         },
         {
           "kind": "TypeNominal",
@@ -73893,21 +84539,15 @@
           "hasDefaultArg": true,
           "usr": "s:SS"
         }
-      ]
+      ],
+      "declKind": "Func",
+      "usr": "s:s10debugPrint_9separator10terminatoryypd_S2StF",
+      "moduleName": "Swift"
     },
     {
       "kind": "Function",
       "name": "print",
       "printedName": "print(_:separator:terminator:to:)",
-      "declKind": "Func",
-      "usr": "s:s5print_9separator10terminator2toyypd_S2Sxzts16TextOutputStreamRzlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Target where Target : TextOutputStream>",
-      "declAttributes": [
-        "Inline",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -73918,14 +84558,14 @@
           "kind": "TypeNominal",
           "name": "Array",
           "printedName": "[Any]",
-          "usr": "s:Sa",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ProtocolComposition",
               "printedName": "Any"
             }
-          ]
+          ],
+          "usr": "s:Sa"
         },
         {
           "kind": "TypeNominal",
@@ -73946,21 +84586,16 @@
           "name": "GenericTypeParam",
           "printedName": "Target"
         }
-      ]
+      ],
+      "declKind": "Func",
+      "usr": "s:s5print_9separator10terminator2toyypd_S2Sxzts16TextOutputStreamRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<Target where Target : TextOutputStream>"
     },
     {
       "kind": "Function",
       "name": "debugPrint",
       "printedName": "debugPrint(_:separator:terminator:to:)",
-      "declKind": "Func",
-      "usr": "s:s10debugPrint_9separator10terminator2toyypd_S2Sxzts16TextOutputStreamRzlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Target where Target : TextOutputStream>",
-      "declAttributes": [
-        "Inline",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -73971,14 +84606,14 @@
           "kind": "TypeNominal",
           "name": "Array",
           "printedName": "[Any]",
-          "usr": "s:Sa",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ProtocolComposition",
               "printedName": "Any"
             }
-          ]
+          ],
+          "usr": "s:Sa"
         },
         {
           "kind": "TypeNominal",
@@ -73999,27 +84634,21 @@
           "name": "GenericTypeParam",
           "printedName": "Target"
         }
-      ]
+      ],
+      "declKind": "Func",
+      "usr": "s:s10debugPrint_9separator10terminator2toyypd_S2Sxzts16TextOutputStreamRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<Target where Target : TextOutputStream>"
     },
     {
       "kind": "TypeDecl",
       "name": "RandomNumberGenerator",
       "printedName": "RandomNumberGenerator",
-      "declKind": "Protocol",
-      "usr": "s:SG",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:SG4nexts6UInt64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomNumberGenerator>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -74027,42 +84656,38 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SG4nexts6UInt64VyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RandomNumberGenerator>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:SGsE4nextqd__ys17FixedWidthIntegerRd__SURd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : RandomNumberGenerator, T : FixedWidthInteger, T : UnsignedInteger>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SGsE4nextqd__ys17FixedWidthIntegerRd__SURd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : RandomNumberGenerator, T : FixedWidthInteger, T : UnsignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next(upperBound:)",
-          "declKind": "Func",
-          "usr": "s:SGsE4next10upperBoundqd__qd___ts17FixedWidthIntegerRd__SURd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : RandomNumberGenerator, T : FixedWidthInteger, T : UnsignedInteger>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -74074,36 +84699,30 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SGsE4next10upperBoundqd__qd___ts17FixedWidthIntegerRd__SURd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : RandomNumberGenerator, T : FixedWidthInteger, T : UnsignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SG",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "SystemRandomNumberGenerator",
       "printedName": "SystemRandomNumberGenerator",
-      "declKind": "Struct",
-      "usr": "s:s27SystemRandomNumberGeneratorV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "RandomNumberGenerator"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s27SystemRandomNumberGeneratorVABycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -74111,20 +84730,18 @@
               "printedName": "SystemRandomNumberGenerator",
               "usr": "s:s27SystemRandomNumberGeneratorV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s27SystemRandomNumberGeneratorVABycfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s27SystemRandomNumberGeneratorV4nexts6UInt64VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -74132,33 +84749,75 @@
               "printedName": "UInt64",
               "usr": "s:s6UInt64V"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s27SystemRandomNumberGeneratorV4nexts6UInt64VyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s27SystemRandomNumberGeneratorV",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "RandomNumberGenerator"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "RandomAccessCollection",
       "printedName": "RandomAccessCollection",
-      "declKind": "Protocol",
-      "usr": "s:Sk",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : BidirectionalCollection, Self.Indices : RandomAccessCollection, Self.SubSequence : RandomAccessCollection>",
-      "conformingProtocols": [
-        "BidirectionalCollection",
-        "Collection",
-        "Sequence"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Element",
+          "printedName": "Element",
+          "declKind": "AssociatedType",
+          "usr": "s:Sk7ElementQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Index",
+          "printedName": "Index",
+          "declKind": "AssociatedType",
+          "usr": "s:Sk5IndexQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "declKind": "AssociatedType",
+          "usr": "s:Sk11SubSequenceQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Indices",
+          "printedName": "Indices",
+          "declKind": "AssociatedType",
+          "usr": "s:Sk7IndicesQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:Sk7indices7IndicesQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -74169,29 +84828,96 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sk7indices7IndicesQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : RandomAccessCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Indices"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sk7indices7IndicesQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : RandomAccessCollection>",
+              "overriding": true,
+              "declAttributes": [
+                "Override"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sk7indices7IndicesQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.SubSequence"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Self.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "Self.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Sky11SubSequenceQzSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RandomAccessCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Index"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Sky7ElementQz5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RandomAccessCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:Sk10startIndex0B0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -74202,29 +84928,36 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sk10startIndex0B0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : RandomAccessCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sk10startIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : RandomAccessCollection>",
+              "overriding": true,
+              "declAttributes": [
+                "Override"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sk10startIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:Sk8endIndex0B0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -74235,30 +84968,36 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sk8endIndex0B0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : RandomAccessCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sk8endIndex0B0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : RandomAccessCollection>",
+              "overriding": true,
+              "declAttributes": [
+                "Override"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sk8endIndex0B0Qzvp",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:Sk5index6before5IndexQzAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -74270,17 +85009,21 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sk5index6before5IndexQzAD_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RandomAccessCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:Sk9formIndex6beforey0B0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -74292,17 +85035,21 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sk9formIndex6beforey0B0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RandomAccessCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:Sk5index5after5IndexQzAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -74314,17 +85061,21 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sk5index5after5IndexQzAD_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RandomAccessCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:Sk9formIndex5aftery0B0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -74336,17 +85087,21 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sk9formIndex5aftery0B0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RandomAccessCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:Sk5index_8offsetBy5IndexQzAD_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -74364,30 +85119,30 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sk5index_8offsetBy5IndexQzAD_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RandomAccessCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:Sk5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -74405,17 +85160,17 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sk5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RandomAccessCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:Sk8distance4from2toSi5IndexQz_AEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -74433,33 +85188,30 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sk8distance4from2toSi5IndexQz_AEtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RandomAccessCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SksE5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -74477,72 +85229,69 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SksE5index_8offsetBy07limitedC05IndexQzSgAE_SiAEtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RandomAccessCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE7indicesACvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Self.Index>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE7indicesACvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : RandomAccessCollection, Self.Index : Strideable, Self.Indices == Range<Self.Index>, Self.Index.Stride == Int>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<Self.Index>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Self.Index"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE7indicesACvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : RandomAccessCollection, Self.Index : Strideable, Self.Indices == Range<Self.Index>, Self.Index.Stride == Int>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE7indicesACvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE5index5afterA2B_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection, Self.Index : Strideable, Self.Indices == Range<Self.Index>, Self.Index.Stride == Int>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -74554,20 +85303,19 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE5index5afterA2B_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RandomAccessCollection, Self.Index : Strideable, Self.Indices == Range<Self.Index>, Self.Index.Stride == Int>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE5index6beforeA2B_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection, Self.Index : Strideable, Self.Indices == Range<Self.Index>, Self.Index.Stride == Int>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -74579,20 +85327,19 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE5index6beforeA2B_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RandomAccessCollection, Self.Index : Strideable, Self.Indices == Range<Self.Index>, Self.Index.Stride == Int>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE5index_8offsetByA2B_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection, Self.Index : Strideable, Self.Indices == Range<Self.Index>, Self.Index.Stride == Int>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -74609,20 +85356,19 @@
               "name": "DependentMember",
               "printedName": "Self.Index.Stride"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE5index_8offsetByA2B_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RandomAccessCollection, Self.Index : Strideable, Self.Indices == Range<Self.Index>, Self.Index.Stride == Int>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE8distance4from2toSiAB_ABtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RandomAccessCollection, Self.Index : Strideable, Self.Indices == Range<Self.Index>, Self.Index.Stride == Int>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -74639,59 +85385,74 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SksSx5IndexRpzSnyABG7IndicesRtzSiAA_6StrideRTzrlE8distance4from2toSiAB_ABtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RandomAccessCollection, Self.Index : Strideable, Self.Indices == Range<Self.Index>, Self.Index.Stride == Int>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:Sk",
+      "moduleName": "Swift",
+      "genericSig": "<Self : BidirectionalCollection, Self.Indices : RandomAccessCollection, Self.SubSequence : RandomAccessCollection>",
+      "conformingProtocols": [
+        "BidirectionalCollection",
+        "Collection",
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "RangeExpression",
       "printedName": "RangeExpression",
-      "declKind": "Protocol",
-      "usr": "s:SX",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self.Bound : Comparable>",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Bound",
+          "printedName": "Bound",
+          "declKind": "AssociatedType",
+          "usr": "s:SX5BoundQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Function",
           "name": "relative",
           "printedName": "relative(to:)",
-          "declKind": "Func",
-          "usr": "s:SX8relative2toSny5BoundQzGqd___tSlRd__5IndexQyd__ADRSlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, C where Self : RangeExpression, C : Collection, Self.Bound == C.Index>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Self.Bound>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Bound"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "C"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SX8relative2toSny5BoundQzGqd___tSlRd__5IndexQyd__ADRSlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, C where Self : RangeExpression, C : Collection, Self.Bound == C.Index>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:SX8containsySb5BoundQzF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeExpression>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -74704,43 +85465,59 @@
               "name": "DependentMember",
               "printedName": "Self.Bound"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SX8containsySb5BoundQzF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeExpression>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "~=",
+          "printedName": "~=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Bound"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SXsE2teoiySbx_5BoundQztFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeExpression>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:SX",
+      "moduleName": "Swift",
+      "genericSig": "<Self.Bound : Comparable>"
     },
     {
       "kind": "TypeDecl",
       "name": "Range",
       "printedName": "Range",
-      "declKind": "Struct",
-      "usr": "s:Sn",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Bound where Bound : Comparable>",
-      "conformingProtocols": [
-        "Sequence",
-        "Collection",
-        "BidirectionalCollection",
-        "RandomAccessCollection",
-        "RangeExpression",
-        "CustomStringConvertible",
-        "CustomDebugStringConvertible",
-        "CustomReflectable",
-        "Equatable",
-        "Hashable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "lowerBound",
           "printedName": "lowerBound",
-          "declKind": "Var",
-          "usr": "s:Sn10lowerBoundxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -74751,32 +85528,34 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sn10lowerBoundxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sn10lowerBoundxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Comparable>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sn10lowerBoundxvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Var",
           "name": "upperBound",
           "printedName": "upperBound",
-          "declKind": "Var",
-          "usr": "s:Sn10upperBoundxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -74787,49 +85566,47 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sn10upperBoundxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sn10upperBoundxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Comparable>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sn10upperBoundxvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(uncheckedBounds:)",
-          "declKind": "Constructor",
-          "usr": "s:Sn15uncheckedBoundsSnyxGx5lower_x5uppert_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Bound>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
@@ -74862,20 +85639,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sn15uncheckedBoundsSnyxGx5lower_x5uppert_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:Sn8containsySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -74888,19 +85664,19 @@
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sn8containsySbxF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "isEmpty",
           "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:Sn7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -74912,11 +85688,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sn7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -74924,138 +85695,136 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sn7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Comparable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sn7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "IndexingIterator",
               "printedName": "IndexingIterator<Range<Bound>>",
-              "usr": "s:s16IndexingIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<Bound>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Bound"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
-              ]
+              ],
+              "usr": "s:s16IndexingIteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
         },
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Bound>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Bound>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE10startIndexxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -75066,32 +85835,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SnsSxRzSZ6StrideRpzrlE10startIndexxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SnsSxRzSZ6StrideRpzrlE10startIndexxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE10startIndexxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE8endIndexxvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -75102,33 +85869,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SnsSxRzSZ6StrideRpzrlE8endIndexxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SnsSxRzSZ6StrideRpzrlE8endIndexxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE8endIndexxvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE5index5afterxx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -75154,20 +85918,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE5index5afterxx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE5index6beforexx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -75193,20 +85956,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE5index6beforexx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE5index_8offsetByxx_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -75238,20 +86000,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE5index_8offsetByxx_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE8distance4from2toSix_xtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -75283,88 +86044,24 @@
                 }
               ]
             }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "indices",
-          "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlE7indicesSnyxGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Bound>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SnsSxRzSZ6StrideRpzrlE7indicesSnyxGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Range",
-                  "printedName": "Range<Bound>",
-                  "usr": "s:Sn",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Bound"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlEySnyxGSNyxGcfc",
-          "location": "",
+          "declKind": "Func",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE8distance4from2toSix_xtF",
           "moduleName": "Swift",
           "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
-              "printedName": "Range<Bound>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Bound"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "ClosedRange",
-              "printedName": "ClosedRange<Range<Bound>.Bound>",
-              "usr": "s:SN",
+              "printedName": "Range<Range<Bound>.Bound>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -75378,113 +86075,264 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Range<Bound>.Index>",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "Range<Bound>.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sn"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlEySnyxGACcip",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "Function",
-          "name": "relative",
-          "printedName": "relative(to:)",
-          "declKind": "Func",
-          "usr": "s:Sn8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound, C where Bound == C.Index, C : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
+          "kind": "Var",
+          "name": "indices",
+          "printedName": "indices",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Bound>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Bound>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Bound"
+                    }
+                  ],
+                  "usr": "s:Sn"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SnsSxRzSZ6StrideRpzrlE7indicesSnyxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlE7indicesSnyxGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Element",
+              "printedName": "Range<Bound>.Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
               ]
             },
             {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "Range<Bound>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlEyxxcip",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Bound>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Bound"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<Range<Bound>.Bound>",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Bound",
+                  "printedName": "Range<Bound>.Bound",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:SN"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlEySnyxGSNyxGcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
+        },
+        {
+          "kind": "Function",
+          "name": "relative",
+          "printedName": "relative(to:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Bound>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Bound"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "C"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sn8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound, C where Bound == C.Index, C : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Bound",
           "printedName": "Bound",
-          "declKind": "TypeAlias",
-          "usr": "s:Sn5Bounda",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sn5Bounda",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "clamped",
           "printedName": "clamped(to:)",
-          "declKind": "Func",
-          "usr": "s:Sn7clamped2toSnyxGAC_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Bound>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Bound>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sn7clamped2toSnyxGAC_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:Sn11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -75496,11 +86344,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sn11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -75508,18 +86351,24 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sn11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Comparable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sn11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Sn16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -75531,11 +86380,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sn16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -75543,18 +86387,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sn16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Comparable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sn16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Sn12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -75566,11 +86413,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sn12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -75578,22 +86420,68 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sn12customMirrors0B0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Comparable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sn12customMirrors0B0Vvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Bound>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Bound"
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Bound>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Bound"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sn2eeoiySbSnyxG_ABtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SnsSHRzrlE4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable, Bound : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -75606,16 +86494,19 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SnsSHRzrlE4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable, Bound : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SnsSHRzrlE9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -75627,11 +86518,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SnsSHRzrlE9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable, Bound : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -75639,22 +86525,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SnsSHRzrlE9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Comparable, Bound : Hashable>",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SnsSHRzrlE9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "overlaps",
           "printedName": "overlaps(_:)",
-          "declKind": "Func",
-          "usr": "s:Sn8overlapsySbSnyxGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -75666,7 +86553,6 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Range<Bound>.Bound>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -75680,22 +86566,22 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sn8overlapsySbSnyxGF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "overlaps",
           "printedName": "overlaps(_:)",
-          "declKind": "Func",
-          "usr": "s:Sn8overlapsySbSNyxGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -75707,7 +86593,6 @@
               "kind": "TypeNominal",
               "name": "ClosedRange",
               "printedName": "ClosedRange<Range<Bound>.Bound>",
-              "usr": "s:SN",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -75721,41 +86606,40 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:SN"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sn8overlapsySbSNyxGF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SnsSxRzSZ6StrideRpzrlEySnyxGACcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Bound>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Range<Bound>.Bound>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -75769,36 +86653,49 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SnsSxRzSZ6StrideRpzrlEySnyxGACcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:Sn",
+      "moduleName": "Swift",
+      "genericSig": "<Bound where Bound : Comparable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "Collection",
+        "BidirectionalCollection",
+        "RandomAccessCollection",
+        "RangeExpression",
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible",
+        "CustomReflectable",
+        "Equatable",
+        "Hashable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "PartialRangeUpTo",
       "printedName": "PartialRangeUpTo",
-      "declKind": "Struct",
-      "usr": "s:s16PartialRangeUpToV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Bound where Bound : Comparable>",
-      "conformingProtocols": [
-        "RangeExpression"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "upperBound",
           "printedName": "upperBound",
-          "declKind": "Var",
-          "usr": "s:s16PartialRangeUpToV10upperBoundxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -75809,49 +86706,47 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s16PartialRangeUpToV10upperBoundxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s16PartialRangeUpToV10upperBoundxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Comparable>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s16PartialRangeUpToV10upperBoundxvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s16PartialRangeUpToVyAByxGxcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "PartialRangeUpTo",
               "printedName": "PartialRangeUpTo<Bound>",
-              "usr": "s:s16PartialRangeUpToV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "usr": "s:s16PartialRangeUpToV"
             },
             {
               "kind": "TypeNameAlias",
@@ -75865,53 +86760,51 @@
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s16PartialRangeUpToVyAByxGxcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "relative",
           "printedName": "relative(to:)",
-          "declKind": "Func",
-          "usr": "s:s16PartialRangeUpToV8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound, C where Bound == C.Index, C : Collection>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Bound>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "C"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16PartialRangeUpToV8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound, C where Bound == C.Index, C : Collection>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:s16PartialRangeUpToV8containsySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -75924,51 +86817,53 @@
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16PartialRangeUpToV8containsySbxF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Bound",
           "printedName": "Bound",
-          "declKind": "TypeAlias",
-          "usr": "s:s16PartialRangeUpToV5Bounda",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s16PartialRangeUpToV5Bounda",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s16PartialRangeUpToV",
+      "moduleName": "Swift",
+      "genericSig": "<Bound where Bound : Comparable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "RangeExpression"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "PartialRangeThrough",
       "printedName": "PartialRangeThrough",
-      "declKind": "Struct",
-      "usr": "s:s19PartialRangeThroughV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Bound where Bound : Comparable>",
-      "conformingProtocols": [
-        "RangeExpression"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "upperBound",
           "printedName": "upperBound",
-          "declKind": "Var",
-          "usr": "s:s19PartialRangeThroughV10upperBoundxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -75979,102 +86874,98 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s19PartialRangeThroughV10upperBoundxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s19PartialRangeThroughV10upperBoundxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Comparable>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s19PartialRangeThroughV10upperBoundxvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s19PartialRangeThroughVyAByxGxcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "PartialRangeThrough",
               "printedName": "PartialRangeThrough<Bound>",
-              "usr": "s:s19PartialRangeThroughV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "usr": "s:s19PartialRangeThroughV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s19PartialRangeThroughVyAByxGxcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "relative",
           "printedName": "relative(to:)",
-          "declKind": "Func",
-          "usr": "s:s19PartialRangeThroughV8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound, C where Bound == C.Index, C : Collection>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Bound>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "C"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s19PartialRangeThroughV8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound, C where Bound == C.Index, C : Collection>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:s19PartialRangeThroughV8containsySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -76087,52 +86978,53 @@
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s19PartialRangeThroughV8containsySbxF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Bound",
           "printedName": "Bound",
-          "declKind": "TypeAlias",
-          "usr": "s:s19PartialRangeThroughV5Bounda",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s19PartialRangeThroughV5Bounda",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s19PartialRangeThroughV",
+      "moduleName": "Swift",
+      "genericSig": "<Bound where Bound : Comparable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "RangeExpression"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "PartialRangeFrom",
       "printedName": "PartialRangeFrom",
-      "declKind": "Struct",
-      "usr": "s:s16PartialRangeFromV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Bound where Bound : Comparable>",
-      "conformingProtocols": [
-        "RangeExpression",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "lowerBound",
           "printedName": "lowerBound",
-          "declKind": "Var",
-          "usr": "s:s16PartialRangeFromV10lowerBoundxvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -76143,49 +87035,47 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s16PartialRangeFromV10lowerBoundxvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Comparable>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s16PartialRangeFromV10lowerBoundxvg",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Comparable>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s16PartialRangeFromV10lowerBoundxvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s16PartialRangeFromVyAByxGxcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "PartialRangeFrom",
               "printedName": "PartialRangeFrom<Bound>",
-              "usr": "s:s16PartialRangeFromV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "usr": "s:s16PartialRangeFromV"
             },
             {
               "kind": "TypeNameAlias",
@@ -76199,53 +87089,51 @@
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s16PartialRangeFromVyAByxGxcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "relative",
           "printedName": "relative(to:)",
-          "declKind": "Func",
-          "usr": "s:s16PartialRangeFromV8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound, C where Bound == C.Index, C : Collection>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Bound>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "C"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16PartialRangeFromV8relative2toSnyxGqd___t5IndexQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound, C where Bound == C.Index, C : Collection>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:s16PartialRangeFromV8containsySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -76258,77 +87146,62 @@
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16PartialRangeFromV8containsySbxF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Bound",
           "printedName": "Bound",
-          "declKind": "TypeAlias",
-          "usr": "s:s16PartialRangeFromV5Bounda",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Comparable>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s16PartialRangeFromV5Bounda",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Comparable>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
         },
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "conformingProtocols": [
-            "IteratorProtocol"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE8IteratorV4nextxSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "PartialRangeFrom<Bound>.Bound?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -76342,41 +87215,52 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE8IteratorV4nextxSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE8IteratorV7Elementa",
+              "moduleName": "Swift",
+              "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE12makeIteratorABsSxRzSZADRQrlE0F0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -76384,42 +87268,86 @@
               "printedName": "PartialRangeFrom<Bound>.Iterator",
               "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE12makeIteratorABsSxRzSZADRQrlE0F0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Bound>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Bound"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s16PartialRangeFromVsSxRzSZ6StrideRpzrlE11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s16PartialRangeFromV",
+      "moduleName": "Swift",
+      "genericSig": "<Bound where Bound : Comparable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "RangeExpression",
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnboundedRange_",
       "printedName": "UnboundedRange_",
+      "children": [
+        {
+          "kind": "Function",
+          "name": "...",
+          "printedName": "...(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnboundedRange_",
+              "printedName": "UnboundedRange_",
+              "usr": "s:s15UnboundedRange_O"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15UnboundedRange_O3zzzoPyyABFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Postfix"
+          ]
+        }
+      ],
       "declKind": "Enum",
       "usr": "s:s15UnboundedRange_O",
-      "location": "",
       "moduleName": "Swift",
       "declAttributes": [
         "Frozen"
@@ -76429,10 +87357,6 @@
       "kind": "TypeAlias",
       "name": "UnboundedRange",
       "printedName": "UnboundedRange",
-      "declKind": "TypeAlias",
-      "usr": "s:s14UnboundedRangea",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeFunc",
@@ -76448,7 +87372,6 @@
               "kind": "TypeNominal",
               "name": "Paren",
               "printedName": "(UnboundedRange_)",
-              "usr": "s:s15UnboundedRange_O",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -76456,103 +87379,100 @@
                   "printedName": "UnboundedRange_",
                   "usr": "s:s15UnboundedRange_O"
                 }
-              ]
+              ],
+              "usr": "s:s15UnboundedRange_O"
             }
           ]
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s14UnboundedRangea",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "CountableRange",
       "printedName": "CountableRange",
-      "declKind": "TypeAlias",
-      "usr": "s:s14CountableRangea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Range",
           "printedName": "Range<Bound>",
-          "usr": "s:Sn",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
-          ]
+          ],
+          "usr": "s:Sn"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s14CountableRangea",
+      "moduleName": "Swift",
+      "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
     },
     {
       "kind": "TypeAlias",
       "name": "CountablePartialRangeFrom",
       "printedName": "CountablePartialRangeFrom",
-      "declKind": "TypeAlias",
-      "usr": "s:s25CountablePartialRangeFroma",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>",
       "children": [
         {
           "kind": "TypeNominal",
           "name": "PartialRangeFrom",
           "printedName": "PartialRangeFrom<Bound>",
-          "usr": "s:s16PartialRangeFromV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Bound"
             }
-          ]
+          ],
+          "usr": "s:s16PartialRangeFromV"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s25CountablePartialRangeFroma",
+      "moduleName": "Swift",
+      "genericSig": "<Bound where Bound : Strideable, Bound.Stride : SignedInteger>"
     },
     {
       "kind": "TypeDecl",
       "name": "RangeReplaceableCollection",
       "printedName": "RangeReplaceableCollection",
-      "declKind": "Protocol",
-      "usr": "s:Sm",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Collection, Self.SubSequence : RangeReplaceableCollection>",
-      "conformingProtocols": [
-        "Collection",
-        "Sequence"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "declKind": "AssociatedType",
+          "usr": "s:Sm11SubSequenceQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:Smxycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Smxycfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "replaceSubrange",
           "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:Sm15replaceSubrange_4withySny5IndexQzG_qd__tSlRd__7ElementQyd__AFRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, C where Self : RangeReplaceableCollection, C : Collection, Self.Element == C.Element>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76563,32 +87483,32 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Self.Index>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "C"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm15replaceSubrange_4withySny5IndexQzG_qd__ntSlRd__7ElementQyd__AFRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, C where Self : RangeReplaceableCollection, C : Collection, Self.Element == C.Element>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "reserveCapacity",
           "printedName": "reserveCapacity(_:)",
-          "declKind": "Func",
-          "usr": "s:Sm15reserveCapacityyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76601,17 +87521,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm15reserveCapacityyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(repeating:count:)",
-          "declKind": "Constructor",
-          "usr": "s:Sm9repeating5countx7ElementQz_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -76629,17 +87550,17 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sm9repeating5countx7ElementQz_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:Smyxqd__cSTRd__7ElementQyd__AARtzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, S where Self : RangeReplaceableCollection, S : Sequence, Self.Element == S.Element>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -76651,18 +87572,17 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Smyxqd__cSTRd__7ElementQyd__AARtzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, S where Self : RangeReplaceableCollection, S : Sequence, Self.Element == S.Element>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(_:)",
-          "declKind": "Func",
-          "usr": "s:Sm6appendyy7ElementQznF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76674,18 +87594,18 @@
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm6appendyy7ElementQznF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:Sm6append10contentsOfyqd__n_tSTRd__7ElementQyd__ACRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, S where Self : RangeReplaceableCollection, S : Sequence, Self.Element == S.Element>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76697,18 +87617,18 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm6append10contentsOfyqd__n_tSTRd__7ElementQyd__ACRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, S where Self : RangeReplaceableCollection, S : Sequence, Self.Element == S.Element>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(_:at:)",
-          "declKind": "Func",
-          "usr": "s:Sm6insert_2aty7ElementQzn_5IndexQztF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76725,18 +87645,18 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm6insert_2aty7ElementQzn_5IndexQztF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(contentsOf:at:)",
-          "declKind": "Func",
-          "usr": "s:Sm6insert10contentsOf2atyqd__n_5IndexQztSlRd__7ElementQyd__AFRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, S where Self : RangeReplaceableCollection, S : Collection, Self.Element == S.Element>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76753,21 +87673,18 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm6insert10contentsOf2atyqd__n_5IndexQztSlRd__7ElementQyd__AFRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, S where Self : RangeReplaceableCollection, S : Collection, Self.Element == S.Element>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "remove",
           "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:Sm6remove2at7ElementQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -76779,18 +87696,21 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm6remove2at7ElementQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "declAttributes": [
+            "DiscardableResult"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeSubrange",
           "printedName": "removeSubrange(_:)",
-          "declKind": "Func",
-          "usr": "s:Sm14removeSubrangeyySny5IndexQzGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76801,48 +87721,48 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Self.Index>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm14removeSubrangeyySny5IndexQzGF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeFirst",
           "printedName": "removeFirst()",
-          "declKind": "Func",
-          "usr": "s:Sm11removeFirst7ElementQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm11removeFirst7ElementQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "declAttributes": [
+            "DiscardableResult"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeFirst",
           "printedName": "removeFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:Sm11removeFirstyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76855,18 +87775,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm11removeFirstyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeAll",
           "printedName": "removeAll(keepingCapacity:)",
-          "declKind": "Func",
-          "usr": "s:Sm9removeAll15keepingCapacityySb_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -76879,22 +87799,18 @@
               "printedName": "Bool",
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm9removeAll15keepingCapacityySb_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeAll",
           "printedName": "removeAll(where:)",
-          "declKind": "Func",
-          "usr": "s:Sm9removeAll5whereySb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -76905,9 +87821,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -76927,22 +87840,87 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sm9removeAll5whereySb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true,
+          "mutating": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Index"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Smy7ElementQz5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.SubSequence"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Self.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "Self.Index"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Smy11SubSequenceQzSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "protocolReq": true,
+          "overriding": true,
+          "declAttributes": [
+            "Override"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(repeating:count:)",
-          "declKind": "Constructor",
-          "usr": "s:SmsE9repeating5countx7ElementQz_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -76960,20 +87938,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SmsE9repeating5countx7ElementQz_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SmsEyxqd__cSTRd__7ElementQyd__AARtzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, S where Self : RangeReplaceableCollection, S : Sequence, Self.Element == S.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -76985,21 +87962,19 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SmsEyxqd__cSTRd__7ElementQyd__AARtzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, S where Self : RangeReplaceableCollection, S : Sequence, Self.Element == S.Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(_:)",
-          "declKind": "Func",
-          "usr": "s:SmsE6appendyy7ElementQzF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77011,21 +87986,20 @@
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE6appendyy7ElementQznF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:SmsE6append10contentsOfyqd___tSTRd__7ElementQyd__ACRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, S where Self : RangeReplaceableCollection, S : Sequence, Self.Element == S.Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77037,21 +88011,20 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE6append10contentsOfyqd__n_tSTRd__7ElementQyd__ACRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, S where Self : RangeReplaceableCollection, S : Sequence, Self.Element == S.Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(_:at:)",
-          "declKind": "Func",
-          "usr": "s:SmsE6insert_2aty7ElementQz_5IndexQztF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77068,21 +88041,20 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE6insert_2aty7ElementQzn_5IndexQztF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(contentsOf:at:)",
-          "declKind": "Func",
-          "usr": "s:SmsE6insert10contentsOf2atyqd___5IndexQztSlRd__7ElementQyd__AFRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, C where Self : RangeReplaceableCollection, C : Collection, Self.Element == C.Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77099,22 +88071,20 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE6insert10contentsOf2atyqd__n_5IndexQztSlRd__7ElementQyd__AFRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, C where Self : RangeReplaceableCollection, C : Collection, Self.Element == C.Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "remove",
           "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:SmsE6remove2at7ElementQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77126,21 +88096,21 @@
               "name": "DependentMember",
               "printedName": "Self.Index"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE6remove2at7ElementQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeSubrange",
           "printedName": "removeSubrange(_:)",
-          "declKind": "Func",
-          "usr": "s:SmsE14removeSubrangeyySny5IndexQzGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77151,30 +88121,29 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Self.Index>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE14removeSubrangeyySny5IndexQzGF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeFirst",
           "printedName": "removeFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:SmsE11removeFirstyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77187,43 +88156,41 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE11removeFirstyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeFirst",
           "printedName": "removeFirst()",
-          "declKind": "Func",
-          "usr": "s:SmsE11removeFirst7ElementQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE11removeFirst7ElementQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeAll",
           "printedName": "removeAll(keepingCapacity:)",
-          "declKind": "Func",
-          "usr": "s:SmsE9removeAll15keepingCapacityySb_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77237,21 +88204,20 @@
               "hasDefaultArg": true,
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE9removeAll15keepingCapacityySb_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "reserveCapacity",
           "printedName": "reserveCapacity(_:)",
-          "declKind": "Func",
-          "usr": "s:SmsE15reserveCapacityyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77264,43 +88230,41 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE15reserveCapacityyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeFirst",
           "printedName": "removeFirst()",
-          "declKind": "Func",
-          "usr": "s:Sms11SubSequenceQzRszrlE11removeFirst7ElementQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sms11SubSequenceQzRszrlE11removeFirst7ElementQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection, Self == Self.SubSequence>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeFirst",
           "printedName": "removeFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:Sms11SubSequenceQzRszrlE11removeFirstyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : RangeReplaceableCollection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77313,21 +88277,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sms11SubSequenceQzRszrlE11removeFirstyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection, Self == Self.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "replaceSubrange",
           "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:SmsE15replaceSubrange_4withyqd_0__qd__tSlRd__SXRd_0_7ElementQyd__ACRtz5BoundQyd_0_5IndexRtzr0_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, C, R where Self : RangeReplaceableCollection, C : Collection, R : RangeExpression, Self.Element == C.Element, Self.Index == R.Bound>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77344,21 +88307,20 @@
               "name": "GenericTypeParam",
               "printedName": "C"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE15replaceSubrange_4withyqd_0__qd__ntSlRd__SXRd_0_7ElementQyd__ACRtz5BoundQyd_0_5IndexRtzr0_lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, C, R where Self : RangeReplaceableCollection, C : Collection, R : RangeExpression, Self.Element == C.Element, Self.Index == R.Bound>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeSubrange",
           "printedName": "removeSubrange(_:)",
-          "declKind": "Func",
-          "usr": "s:SmsE14removeSubrangeyyqd__SXRd__5BoundQyd__5IndexRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, R where Self : RangeReplaceableCollection, R : RangeExpression, Self.Index == R.Bound>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77370,72 +88332,69 @@
               "name": "GenericTypeParam",
               "printedName": "R"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE14removeSubrangeyyqd__SXRd__5BoundQyd__5IndexRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, R where Self : RangeReplaceableCollection, R : RangeExpression, Self.Index == R.Bound>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "popLast",
           "printedName": "popLast()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "Self.Element?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "Self.Element"
+                }
+              ],
+              "usr": "s:Sq"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:SmsSKRzrlE7popLast7ElementSTQzSgyF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : BidirectionalCollection, Self : RangeReplaceableCollection>",
-          "mutating": true,
           "declAttributes": [
             "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Self.Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DependentMember",
-                  "printedName": "Self.Element"
-                }
-              ]
-            }
-          ]
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeLast",
           "printedName": "removeLast()",
-          "declKind": "Func",
-          "usr": "s:SmsSKRzrlE10removeLast7ElementSTQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsSKRzrlE10removeLast7ElementSTQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection, Self : RangeReplaceableCollection>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeLast",
           "printedName": "removeLast(_:)",
-          "declKind": "Func",
-          "usr": "s:SmsSKRzrlE10removeLastyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77448,72 +88407,69 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsSKRzrlE10removeLastyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection, Self : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "popLast",
           "printedName": "popLast()",
-          "declKind": "Func",
-          "usr": "s:SmsSKRz11SubSequenceSTQzRszrlE7popLast7ElementSTQzSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self : RangeReplaceableCollection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsSKRz11SubSequenceSTQzRszrlE7popLast7ElementSTQzSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection, Self : RangeReplaceableCollection, Self == Self.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeLast",
           "printedName": "removeLast()",
-          "declKind": "Func",
-          "usr": "s:SmsSKRz11SubSequenceSTQzRszrlE10removeLast7ElementSTQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self : RangeReplaceableCollection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsSKRz11SubSequenceSTQzRszrlE10removeLast7ElementSTQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection, Self : RangeReplaceableCollection, Self == Self.SubSequence>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeLast",
           "printedName": "removeLast(_:)",
-          "declKind": "Func",
-          "usr": "s:SmsSKRz11SubSequenceSTQzRszrlE10removeLastyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : BidirectionalCollection, Self : RangeReplaceableCollection, Self == Self.SubSequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -77526,23 +88482,80 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsSKRz11SubSequenceSTQzRszrlE10removeLastyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : BidirectionalCollection, Self : RangeReplaceableCollection, Self == Self.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE1poiyxx_qd__tSTRd__7ElementQyd__ABRtzlFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : RangeReplaceableCollection, Other : Sequence, Self.Element == Other.Element>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
-          "name": "removeAll",
-          "printedName": "removeAll(where:)",
-          "declKind": "Func",
-          "usr": "s:SmsSMRzrlE9removeAll5whereySb7ElementSTQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : MutableCollection, Self : RangeReplaceableCollection>",
-          "throwing": true,
-          "mutating": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
           ],
+          "declKind": "Func",
+          "usr": "s:SmsE1poiyxqd___xtSTRd__7ElementQyd__ABRtzlFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : RangeReplaceableCollection, Other : Sequence, Self.Element == Other.Element>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -77550,12 +88563,69 @@
               "printedName": "()"
             },
             {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE2peoiyyxz_qd__tSTRd__7ElementQyd__ABRtzlFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : RangeReplaceableCollection, Other : Sequence, Self.Element == Other.Element>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Other"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE1poiyxx_qd__tSmRd__7ElementQyd__ABRtzlFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Other where Self : RangeReplaceableCollection, Other : RangeReplaceableCollection, Self.Element == Other.Element>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "filter",
+          "printedName": "filter(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -77575,25 +88645,27 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "removeAll",
-          "printedName": "removeAll(where:)",
+          ],
           "declKind": "Func",
-          "usr": "s:SmsE9removeAll5whereySb7ElementQzKXE_tKF",
-          "location": "",
+          "usr": "s:SmsE6filteryxSb7ElementQzKXEKF",
           "moduleName": "Swift",
           "genericSig": "<Self where Self : RangeReplaceableCollection>",
-          "throwing": true,
-          "mutating": true,
           "declAttributes": [
             "Rethrows",
+            "Available",
             "Inlinable"
           ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
+          "name": "removeAll",
+          "printedName": "removeAll(where:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -77604,9 +88676,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -77626,39 +88695,92 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsSMRzrlE9removeAll5whereySb7ElementSTQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : MutableCollection, Self : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "removeAll",
+          "printedName": "removeAll(where:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(Self.Element) throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Paren",
+                  "printedName": "(Self.Element)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "Self.Element"
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SmsE9removeAll5whereySb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true,
+          "mutating": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:Sm",
+      "moduleName": "Swift",
+      "genericSig": "<Self : Collection, Self.SubSequence : RangeReplaceableCollection>",
+      "conformingProtocols": [
+        "Collection",
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Repeated",
       "printedName": "Repeated",
-      "declKind": "Struct",
-      "usr": "s:s8RepeatedV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "RandomAccessCollection",
-        "BidirectionalCollection",
-        "Collection",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s8RepeatedV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -77670,14 +88792,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s8RepeatedV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -77685,18 +88799,28 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s8RepeatedV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s8RepeatedV5countSivp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Var",
           "name": "repeatedValue",
           "printedName": "repeatedValue",
-          "declKind": "Var",
-          "usr": "s:s8RepeatedV13repeatedValuexvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -77707,46 +88831,47 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s8RepeatedV13repeatedValuexvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s8RepeatedV13repeatedValuexvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s8RepeatedV13repeatedValuexvp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(count:repeatedValue:)",
-          "declKind": "Constructor",
-          "usr": "s:s8RepeatedV5count13repeatedValueAByxGSi_xtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Repeated",
               "printedName": "Repeated<Element>",
-              "usr": "s:s8RepeatedV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s8RepeatedV"
             },
             {
               "kind": "TypeNominal",
@@ -77759,23 +88884,23 @@
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s8RepeatedV5count13repeatedValueAByxGSi_xtcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true,
+          "isInternal": true
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s8RepeatedV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Int>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -77783,19 +88908,19 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s8RepeatedV7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s8RepeatedV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -77803,19 +88928,16 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s8RepeatedV5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s8RepeatedV10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -77834,11 +88956,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s8RepeatedV10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -77853,21 +88970,24 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s8RepeatedV10startIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s8RepeatedV10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s8RepeatedV8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -77886,11 +89006,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s8RepeatedV8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -77905,120 +89020,160 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s8RepeatedV8endIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s8RepeatedV8endIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s8RepeatedVyxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s8RepeatedV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s8RepeatedV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s8RepeatedV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "IndexingIterator",
               "printedName": "IndexingIterator<Repeated<Element>>",
-              "usr": "s:s16IndexingIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Repeated",
                   "printedName": "Repeated<Element>",
-                  "usr": "s:s8RepeatedV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s8RepeatedV"
                 }
-              ]
+              ],
+              "usr": "s:s16IndexingIteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s8RepeatedV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s8RepeatedV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<Repeated<Element>>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Repeated",
                   "printedName": "Repeated<Element>",
-                  "usr": "s:s8RepeatedV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s8RepeatedV"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s8RepeatedV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s8RepeatedV",
+      "moduleName": "Swift",
+      "genericSig": "<Element>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "RandomAccessCollection",
+        "BidirectionalCollection",
+        "Collection",
+        "Sequence"
       ]
     },
     {
       "kind": "Function",
       "name": "repeatElement",
       "printedName": "repeatElement(_:count:)",
-      "declKind": "Func",
-      "usr": "s:s13repeatElement_5counts8RepeatedVyxGx_SitlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Repeated",
           "printedName": "Repeated<T>",
-          "usr": "s:s8RepeatedV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s8RepeatedV"
         },
         {
           "kind": "TypeNominal",
@@ -78031,108 +89186,75 @@
           "printedName": "Int",
           "usr": "s:Si"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s13repeatElement_5counts8RepeatedVyxGx_SitlF",
+      "moduleName": "Swift",
+      "genericSig": "<T>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "ReversedCollection",
       "printedName": "ReversedCollection",
-      "declKind": "Struct",
-      "usr": "s:s18ReversedCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : BidirectionalCollection>",
-      "conformingProtocols": [
-        "LazySequenceProtocol",
-        "LazyCollectionProtocol",
-        "Sequence",
-        "BidirectionalCollection",
-        "Collection",
-        "RandomAccessCollection"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Elements",
           "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s18ReversedCollectionVss20LazySequenceProtocolRzrlE8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection, Base : LazySequenceProtocol>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ReversedCollection",
               "printedName": "ReversedCollection<Base>",
-              "usr": "s:s18ReversedCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "usr": "s:s18ReversedCollectionV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s18ReversedCollectionVss20LazySequenceProtocolRzrlE8Elementsa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection, Base : LazySequenceProtocol>",
+          "implicit": true
         },
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s18ReversedCollectionV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "conformingProtocols": [
-            "IteratorProtocol",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s18ReversedCollectionV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Element"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s18ReversedCollectionV8IteratorV7Elementa",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : BidirectionalCollection>"
             },
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s18ReversedCollectionV8IteratorV4next7ElementQzSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection>",
-              "mutating": true,
-              "declAttributes": [
-                "Inline",
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "ReversedCollection<Base>.Iterator.Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -78146,19 +89268,24 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s18ReversedCollectionV8IteratorV4next7ElementQzSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : BidirectionalCollection>",
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:s18ReversedCollectionV8IteratorVACa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -78166,65 +89293,71 @@
                   "printedName": "ReversedCollection<Base>.Iterator",
                   "usr": "s:s18ReversedCollectionV8IteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s18ReversedCollectionV8IteratorVACa",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : BidirectionalCollection>",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:s18ReversedCollectionV8IteratorV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnySequence",
                   "printedName": "AnySequence<Base.Element>",
-                  "usr": "s:s11AnySequenceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Base.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s11AnySequenceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s18ReversedCollectionV8IteratorV11SubSequencea",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : BidirectionalCollection>",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s18ReversedCollectionV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "Sequence"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s18ReversedCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s18ReversedCollectionV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>"
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s18ReversedCollectionV12makeIteratorAB0D0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -78232,34 +89365,25 @@
               "printedName": "ReversedCollection<Base>.Iterator",
               "usr": "s:s18ReversedCollectionV8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s18ReversedCollectionV12makeIteratorAB0D0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "Struct",
-          "usr": "s:s18ReversedCollectionV5IndexV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "conformingProtocols": [
-            "Comparable",
-            "Equatable",
-            "Hashable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "base",
               "printedName": "base",
-              "declKind": "Var",
-              "usr": "s:s18ReversedCollectionV5IndexV4baseACQzvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -78270,36 +89394,34 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s18ReversedCollectionV5IndexV4baseACQzvg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Base where Base : BidirectionalCollection>",
-                  "declAttributes": [
-                    "Transparent"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Base.Index"
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s18ReversedCollectionV5IndexV4baseACQzvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Base where Base : BidirectionalCollection>",
+                  "implicit": true,
+                  "declAttributes": [
+                    "Transparent"
                   ]
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s18ReversedCollectionV5IndexV4baseACQzvp",
+              "moduleName": "Swift",
+              "fixedbinaryorder": 0,
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s18ReversedCollectionV5IndexVyADyx_GACQzcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -78312,20 +89434,85 @@
                   "name": "DependentMember",
                   "printedName": "Base.Index"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s18ReversedCollectionV5IndexVyADyx_GACQzcfc",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : BidirectionalCollection>",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ReversedCollection<Base>.Index",
+                  "usr": "s:s18ReversedCollectionV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ReversedCollection<Base>.Index",
+                  "usr": "s:s18ReversedCollectionV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s18ReversedCollectionV5IndexV2eeoiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : BidirectionalCollection>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ReversedCollection<Base>.Index",
+                  "usr": "s:s18ReversedCollectionV5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "ReversedCollection<Base>.Index",
+                  "usr": "s:s18ReversedCollectionV5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s18ReversedCollectionV5IndexV1loiySbADyx_G_AFtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : BidirectionalCollection>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s18ReversedCollectionV5IndexVsSHACRpzrlE4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection, Base.Index : Hashable>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -78338,16 +89525,19 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s18ReversedCollectionV5IndexVsSHACRpzrlE4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : BidirectionalCollection, Base.Index : Hashable>",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s18ReversedCollectionV5IndexVsSHACRpzrlE9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -78359,11 +89549,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s18ReversedCollectionV5IndexVsSHACRpzrlE9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Base where Base : BidirectionalCollection, Base.Index : Hashable>",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -78371,23 +89556,37 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s18ReversedCollectionV5IndexVsSHACRpzrlE9hashValueSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Base where Base : BidirectionalCollection, Base.Index : Hashable>",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s18ReversedCollectionV5IndexVsSHACRpzrlE9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s18ReversedCollectionV5IndexV",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "Comparable",
+            "Equatable",
+            "Hashable"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s18ReversedCollectionV10startIndexAB0D0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -78399,11 +89598,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s18ReversedCollectionV10startIndexAB0D0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -78411,21 +89605,24 @@
                   "printedName": "ReversedCollection<Base>.Index",
                   "usr": "s:s18ReversedCollectionV5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s18ReversedCollectionV10startIndexAB0D0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : BidirectionalCollection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s18ReversedCollectionV10startIndexAB0D0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s18ReversedCollectionV8endIndexAB0D0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -78437,11 +89634,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s18ReversedCollectionV8endIndexAB0D0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : BidirectionalCollection>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -78449,22 +89641,24 @@
                   "printedName": "ReversedCollection<Base>.Index",
                   "usr": "s:s18ReversedCollectionV5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s18ReversedCollectionV8endIndexAB0D0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : BidirectionalCollection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s18ReversedCollectionV8endIndexAB0D0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s18ReversedCollectionV5index5afterAB5IndexVyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -78478,20 +89672,19 @@
               "printedName": "ReversedCollection<Base>.Index",
               "usr": "s:s18ReversedCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s18ReversedCollectionV5index5afterAB5IndexVyx_GAG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s18ReversedCollectionV5index6beforeAB5IndexVyx_GAG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -78505,20 +89698,19 @@
               "printedName": "ReversedCollection<Base>.Index",
               "usr": "s:s18ReversedCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s18ReversedCollectionV5index6beforeAB5IndexVyx_GAG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s18ReversedCollectionV5index_8offsetByAB5IndexVyx_GAG_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -78538,26 +89730,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s18ReversedCollectionV5index_8offsetByAB5IndexVyx_GAG_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s18ReversedCollectionV5index_8offsetBy07limitedE0AB5IndexVyx_GSgAH_SiAHtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "ReversedCollection<Base>.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -78565,7 +89755,8 @@
                   "printedName": "ReversedCollection<Base>.Index",
                   "usr": "s:s18ReversedCollectionV5IndexV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -78585,20 +89776,19 @@
               "printedName": "ReversedCollection<Base>.Index",
               "usr": "s:s18ReversedCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s18ReversedCollectionV5index_8offsetBy07limitedE0AB5IndexVyx_GSgAH_SiAHtF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s18ReversedCollectionV8distance4from2toSiAB5IndexVyx_G_AHtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -78618,148 +89808,263 @@
               "printedName": "ReversedCollection<Base>.Index",
               "usr": "s:s18ReversedCollectionV5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s18ReversedCollectionV8distance4from2toSiAB5IndexVyx_G_AHtF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Element",
+              "printedName": "ReversedCollection<Base>.Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Element"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "ReversedCollection<Base>.Index",
+              "usr": "s:s18ReversedCollectionV5IndexV"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s18ReversedCollectionVy7ElementQzAB5IndexVyx_Gcip",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s18ReversedCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<ReversedCollection<Base>>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ReversedCollection",
                   "printedName": "ReversedCollection<Base>",
-                  "usr": "s:s18ReversedCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Base"
                     }
-                  ]
+                  ],
+                  "usr": "s:s18ReversedCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s18ReversedCollectionV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s18ReversedCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DefaultIndices",
               "printedName": "DefaultIndices<ReversedCollection<Base>>",
-              "usr": "s:SI",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ReversedCollection",
                   "printedName": "ReversedCollection<Base>",
-                  "usr": "s:s18ReversedCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Base"
                     }
-                  ]
+                  ],
+                  "usr": "s:s18ReversedCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:SI"
             }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s18ReversedCollectionV7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "implicit": true
+        },
+        {
+          "kind": "Function",
+          "name": "reversed",
+          "printedName": "reversed()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Base"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s18ReversedCollectionV8reversedxyF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "Available",
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s18ReversedCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<Base where Base : BidirectionalCollection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "LazySequenceProtocol",
+        "LazyCollectionProtocol",
+        "Sequence",
+        "BidirectionalCollection",
+        "Collection",
+        "RandomAccessCollection"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "IteratorProtocol",
       "printedName": "IteratorProtocol",
-      "declKind": "Protocol",
-      "usr": "s:St",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Element",
+          "printedName": "Element",
+          "declKind": "AssociatedType",
+          "usr": "s:St7ElementQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:St4next7ElementQzSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : IteratorProtocol>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:St4next7ElementQzSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : IteratorProtocol>",
+          "protocolReq": true,
+          "mutating": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:St",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "Sequence",
       "printedName": "Sequence",
-      "declKind": "Protocol",
-      "usr": "s:ST",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self.Element == Self.Iterator.Element, Self.Iterator : IteratorProtocol, Self.SubSequence : Sequence, Self.SubSequence == Self.SubSequence.SubSequence, Self.Iterator.Element == Self.SubSequence.Element, Self.SubSequence.Element == Self.SubSequence.Iterator.Element>",
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Element",
+          "printedName": "Element",
+          "declKind": "AssociatedType",
+          "usr": "s:ST7ElementQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Iterator",
+          "printedName": "Iterator",
+          "declKind": "AssociatedType",
+          "usr": "s:ST8IteratorQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "AnySequence",
+              "printedName": "AnySequence<Self.Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "Self.Element"
+                }
+              ],
+              "usr": "s:s11AnySequenceV"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:ST11SubSequenceQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:ST12makeIterator0B0QzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Iterator"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST12makeIterator0B0QzyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:ST19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -78771,11 +90076,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:ST19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -78783,44 +90083,40 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:ST19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Sequence>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:ST19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:ST3mapySayqd__Gqd__7ElementQzKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[T]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> T",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -78839,44 +90135,44 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST3mapySayqd__Gqd__7ElementQzKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : Sequence>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:ST6filterySay7ElementQzGSbACKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Self.Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -78896,23 +90192,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST6filterySay7ElementQzGSbACKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "forEach",
           "printedName": "forEach(_:)",
-          "declKind": "Func",
-          "usr": "s:ST7forEachyyy7ElementQzKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -78923,9 +90222,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -78951,19 +90247,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST7forEachyyy7ElementQzKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:ST9dropFirsty11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -78976,17 +90279,17 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST9dropFirsty11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:ST8dropLasty11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -78999,21 +90302,17 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST8dropLasty11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:ST4drop5while11SubSequenceQzSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -79024,9 +90323,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -79046,19 +90342,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST4drop5while11SubSequenceQzSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(_:)",
-          "declKind": "Func",
-          "usr": "s:ST6prefixy11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -79071,21 +90374,17 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST6prefixy11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:ST6prefix5while11SubSequenceQzSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -79096,9 +90395,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -79118,19 +90414,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST6prefix5while11SubSequenceQzSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:ST6suffixy11SubSequenceQzSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -79143,34 +90446,30 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST6suffixy11SubSequenceQzSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(maxSplits:omittingEmptySubsequences:whereSeparator:)",
-          "declKind": "Func",
-          "usr": "s:ST5split9maxSplits25omittingEmptySubsequences14whereSeparatorSay11SubSequenceQzGSi_S2b7ElementQzKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Self.SubSequence]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.SubSequence"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -79188,9 +90487,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -79210,239 +90506,231 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ST5split9maxSplits25omittingEmptySubsequences14whereSeparatorSay11SubSequenceQzGSi_S2b7ElementQzKXEtKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "shuffled",
           "printedName": "shuffled(using:)",
-          "declKind": "Func",
-          "usr": "s:STsE8shuffled5usingSay7ElementQzGqd__z_tSGRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Sequence, T : RandomNumberGenerator>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Self.Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE8shuffled5usingSay7ElementQzGqd__z_tSGRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : Sequence, T : RandomNumberGenerator>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "shuffled",
           "printedName": "shuffled()",
-          "declKind": "Func",
-          "usr": "s:STsE8shuffledSay7ElementQzGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Self.Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE8shuffledSay7ElementQzGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "joined",
           "printedName": "joined()",
-          "declKind": "Func",
-          "usr": "s:STsST7ElementRpzrlE6joineds15FlattenSequenceVyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.Element : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "FlattenSequence",
               "printedName": "FlattenSequence<Self>",
-              "usr": "s:s15FlattenSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:s15FlattenSequenceV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsST7ElementRpzrlE6joineds15FlattenSequenceVyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence, Self.Element : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "joined",
           "printedName": "joined(separator:)",
-          "declKind": "Func",
-          "usr": "s:STsST7ElementRpzrlE6joined9separators14JoinedSequenceVyxGqd___tSTRd__AA_AAQZAARtd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Separator where Self : Sequence, Separator : Sequence, Self.Element : Sequence, Separator.Element == Self.Element.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "JoinedSequence",
               "printedName": "JoinedSequence<Self>",
-              "usr": "s:s14JoinedSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:s14JoinedSequenceV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Separator"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsST7ElementRpzrlE6joined9separators14JoinedSequenceVyxGqd___tSTRd__AA_AAQZAARtd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Separator where Self : Sequence, Separator : Sequence, Self.Element : Sequence, Separator.Element == Self.Element.Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "lazy",
           "printedName": "lazy",
-          "declKind": "Var",
-          "usr": "s:STsE4lazys12LazySequenceVyxGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "LazySequence",
               "printedName": "LazySequence<Self>",
-              "usr": "s:s12LazySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:s12LazySequenceV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:STsE4lazys12LazySequenceVyxGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "LazySequence",
                   "printedName": "LazySequence<Self>",
-                  "usr": "s:s12LazySequenceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Self"
                     }
-                  ]
+                  ],
+                  "usr": "s:s12LazySequenceV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:STsE4lazys12LazySequenceVyxGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Sequence>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:STsE4lazys12LazySequenceVyxGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:STs8IteratorSTQzRszrlE04makeA0xyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self == Self.Iterator>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STs8IteratorSTQzRszrlE04makeA0xyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence, Self == Self.Iterator>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:STsE3mapySayqd__Gqd__7ElementQzKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[T]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> T",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -79461,45 +90749,44 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE3mapySayqd__Gqd__7ElementQzKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:STsE6filterySay7ElementQzGSbACKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Self.Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -79519,21 +90806,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE6filterySay7ElementQzGSbACKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:STsE19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -79545,11 +90837,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:STsE19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -79557,24 +90844,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:STsE19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : Sequence>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:STsE19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "forEach",
           "printedName": "forEach(_:)",
-          "declKind": "Func",
-          "usr": "s:STsE7forEachyyy7ElementQzKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -79585,9 +90872,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -79613,45 +90897,44 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE7forEachyyy7ElementQzKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "first",
           "printedName": "first(where:)",
-          "declKind": "Func",
-          "usr": "s:STsE5first5where7ElementQzSgSbADKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -79671,35 +90954,39 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE5first5where7ElementQzSgSbADKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(separator:maxSplits:omittingEmptySubsequences:)",
-          "declKind": "Func",
-          "usr": "s:STsSQ7ElementRpzrlE5split9separator9maxSplits25omittingEmptySubsequencesSay11SubSequenceQzGAB_SiSbtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.Element : Equatable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Self.SubSequence]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.SubSequence"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -79720,43 +91007,40 @@
               "hasDefaultArg": true,
               "usr": "s:Sb"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSQ7ElementRpzrlE5split9separator9maxSplits25omittingEmptySubsequencesSay11SubSequenceQzGAB_SiSbtF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence, Self.Element : Equatable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(maxSplits:omittingEmptySubsequences:whereSeparator:)",
-          "declKind": "Func",
-          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAEGSi_S2bADKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[AnySequence<Self.Element>]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnySequence",
                   "printedName": "AnySequence<Self.Element>",
-                  "usr": "s:s11AnySequenceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Self.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s11AnySequenceV"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -79776,9 +91060,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -79798,35 +91079,39 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAEGSi_S2bADKXEtKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE6suffixyAESiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Self.Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
@@ -79834,33 +91119,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE6suffixyAESiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE9dropFirstyAESiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Self.Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
@@ -79868,33 +91152,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE9dropFirstyAESiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE8dropLastyAESiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Self.Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
@@ -79902,43 +91185,37 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE8dropLastyAESiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE4drop5whileAESbADKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Self.Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -79958,35 +91235,39 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE4drop5whileAESbADKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(_:)",
-          "declKind": "Func",
-          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE6prefixyAESiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Self.Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
@@ -79994,43 +91275,37 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE6prefixyAESiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE6prefix5whileAESbADKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Self.Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80050,114 +91325,109 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STss11AnySequenceVy7ElementQzG03SubB0RtzrlE6prefix5whileAESbADKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence, Self.SubSequence == AnySequence<Self.Element>>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst()",
-          "declKind": "Func",
-          "usr": "s:STsE9dropFirst11SubSequenceQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.SubSequence"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE9dropFirst11SubSequenceQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast()",
-          "declKind": "Func",
-          "usr": "s:STsE8dropLast11SubSequenceQzyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.SubSequence"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE8dropLast11SubSequenceQzyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "enumerated",
           "printedName": "enumerated()",
-          "declKind": "Func",
-          "usr": "s:STsE10enumerateds18EnumeratedSequenceVyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "EnumeratedSequence",
               "printedName": "EnumeratedSequence<Self>",
-              "usr": "s:s18EnumeratedSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Self"
                 }
-              ]
+              ],
+              "usr": "s:s18EnumeratedSequenceV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE10enumerateds18EnumeratedSequenceVyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "min",
           "printedName": "min(by:)",
-          "declKind": "Func",
-          "usr": "s:STsE3min2by7ElementQzSgSbAD_ADtKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "WarnUnqualifiedAccess",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element, Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80182,46 +91452,45 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE3min2by7ElementQzSgSbAD_ADtKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "WarnUnqualifiedAccess",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "max",
           "printedName": "max(by:)",
-          "declKind": "Func",
-          "usr": "s:STsE3max2by7ElementQzSgSbAD_ADtKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "WarnUnqualifiedAccess",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element, Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80246,82 +91515,83 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE3max2by7ElementQzSgSbAD_ADtKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "WarnUnqualifiedAccess",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "min",
           "printedName": "min()",
-          "declKind": "Func",
-          "usr": "s:STsSL7ElementRpzrlE3minABSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.Element : Comparable>",
-          "declAttributes": [
-            "WarnUnqualifiedAccess",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSL7ElementRpzrlE3minABSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence, Self.Element : Comparable>",
+          "declAttributes": [
+            "WarnUnqualifiedAccess",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "max",
           "printedName": "max()",
-          "declKind": "Func",
-          "usr": "s:STsSL7ElementRpzrlE3maxABSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.Element : Comparable>",
-          "declAttributes": [
-            "WarnUnqualifiedAccess",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSL7ElementRpzrlE3maxABSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence, Self.Element : Comparable>",
+          "declAttributes": [
+            "WarnUnqualifiedAccess",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "starts",
           "printedName": "starts(with:by:)",
-          "declKind": "Func",
-          "usr": "s:STsE6starts4with2bySbqd___Sb7ElementQz_ADQyd__tKXEtKSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, PossiblePrefix where Self : Sequence, PossiblePrefix : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80338,9 +91608,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element, PossiblePrefix.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80365,22 +91632,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE6starts4with2bySbqd___Sb7ElementQz_ADQyd__tKXEtKSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, PossiblePrefix where Self : Sequence, PossiblePrefix : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "starts",
           "printedName": "starts(with:)",
-          "declKind": "Func",
-          "usr": "s:STsSQ7ElementRpzrlE6starts4withSbqd___tSTRd__AAQyd__ABRSlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, PossiblePrefix where Self : Sequence, PossiblePrefix : Sequence, Self.Element : Equatable, Self.Element == PossiblePrefix.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80393,22 +91664,19 @@
               "name": "GenericTypeParam",
               "printedName": "PossiblePrefix"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSQ7ElementRpzrlE6starts4withSbqd___tSTRd__AAQyd__ABRSlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, PossiblePrefix where Self : Sequence, PossiblePrefix : Sequence, Self.Element : Equatable, Self.Element == PossiblePrefix.Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "elementsEqual",
           "printedName": "elementsEqual(_:by:)",
-          "declKind": "Func",
-          "usr": "s:STsE13elementsEqual_2bySbqd___Sb7ElementQz_ACQyd__tKXEtKSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, OtherSequence where Self : Sequence, OtherSequence : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80425,9 +91693,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element, OtherSequence.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80452,22 +91717,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE13elementsEqual_2bySbqd___Sb7ElementQz_ACQyd__tKXEtKSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, OtherSequence where Self : Sequence, OtherSequence : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "elementsEqual",
           "printedName": "elementsEqual(_:)",
-          "declKind": "Func",
-          "usr": "s:STsSQ7ElementRpzrlE13elementsEqualySbqd__STRd__AAQyd__ABRSlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, OtherSequence where Self : Sequence, OtherSequence : Sequence, Self.Element : Equatable, Self.Element == OtherSequence.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80480,22 +91749,19 @@
               "name": "GenericTypeParam",
               "printedName": "OtherSequence"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSQ7ElementRpzrlE13elementsEqualySbqd__STRd__AAQyd__ABRSlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, OtherSequence where Self : Sequence, OtherSequence : Sequence, Self.Element : Equatable, Self.Element == OtherSequence.Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "lexicographicallyPrecedes",
           "printedName": "lexicographicallyPrecedes(_:by:)",
-          "declKind": "Func",
-          "usr": "s:STsE25lexicographicallyPrecedes_2bySbqd___Sb7ElementQz_ADtKXEtKSTRd__ACQyd__ADRSlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, OtherSequence where Self : Sequence, OtherSequence : Sequence, Self.Element == OtherSequence.Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80512,9 +91778,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element, Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80539,22 +91802,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE25lexicographicallyPrecedes_2bySbqd___Sb7ElementQz_ADtKXEtKSTRd__ACQyd__ADRSlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, OtherSequence where Self : Sequence, OtherSequence : Sequence, Self.Element == OtherSequence.Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "lexicographicallyPrecedes",
           "printedName": "lexicographicallyPrecedes(_:)",
-          "declKind": "Func",
-          "usr": "s:STsSL7ElementRpzrlE25lexicographicallyPrecedesySbqd__STRd__AAQyd__ABRSlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, OtherSequence where Self : Sequence, OtherSequence : Sequence, Self.Element : Comparable, Self.Element == OtherSequence.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80567,22 +91834,19 @@
               "name": "GenericTypeParam",
               "printedName": "OtherSequence"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSL7ElementRpzrlE25lexicographicallyPrecedesySbqd__STRd__AAQyd__ABRSlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, OtherSequence where Self : Sequence, OtherSequence : Sequence, Self.Element : Comparable, Self.Element == OtherSequence.Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(where:)",
-          "declKind": "Func",
-          "usr": "s:STsE8contains5whereS2b7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80594,9 +91858,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80616,24 +91877,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE8contains5whereS2b7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "allSatisfy",
           "printedName": "allSatisfy(_:)",
-          "declKind": "Func",
-          "usr": "s:STsE10allSatisfyyS2b7ElementQzKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80645,9 +91908,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80667,22 +91927,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE10allSatisfyyS2b7ElementQzKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:STsSQ7ElementRpzrlE8containsySbABF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.Element : Equatable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80695,22 +91959,69 @@
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSQ7ElementRpzrlE8containsySbABF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence, Self.Element : Equatable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
+          "name": "count",
+          "printedName": "count(where:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(Self.Element) throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Paren",
+                  "printedName": "(Self.Element)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "Self.Element"
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE5count5whereSiSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Function",
           "name": "reduce",
           "printedName": "reduce(_:_:)",
-          "declKind": "Func",
-          "usr": "s:STsE6reduceyqd__qd___qd__qd___7ElementQztKXEtKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Result where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80726,9 +92037,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Result, Self.Element) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80752,24 +92060,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE6reduceyqd__qd___qd__qd___7ElementQztKXEtKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Result where Self : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "reduce",
           "printedName": "reduce(into:_:)",
-          "declKind": "Func",
-          "usr": "s:STsE6reduce4into_qd__qd___yqd__z_7ElementQztKXEtKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Result where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -80785,9 +92095,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(inout Result, Self.Element) throws -> ()",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80811,73 +92118,71 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE6reduce4into_qd__qd___yqd__z_7ElementQztKXEtKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Result where Self : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "reversed",
           "printedName": "reversed()",
-          "declKind": "Func",
-          "usr": "s:STsE8reversedSay7ElementQzGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Self.Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE8reversedSay7ElementQzGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "flatMap",
           "printedName": "flatMap(_:)",
-          "declKind": "Func",
-          "usr": "s:STsE7flatMapySay7ElementQyd__Gqd__ABQzKXEKSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, SegmentOfResult where Self : Sequence, SegmentOfResult : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[SegmentOfResult.Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "SegmentOfResult.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> SegmentOfResult",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -80896,58 +92201,57 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE7flatMapySay7ElementQyd__Gqd__ABQzKXEKSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, SegmentOfResult where Self : Sequence, SegmentOfResult : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "compactMap",
           "printedName": "compactMap(_:)",
-          "declKind": "Func",
-          "usr": "s:STsE10compactMapySayqd__Gqd__Sg7ElementQzKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, ElementOfResult where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[ElementOfResult]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "ElementOfResult"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> ElementOfResult?",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "ElementOfResult?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "ElementOfResult"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -80961,73 +92265,71 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE10compactMapySayqd__Gqd__Sg7ElementQzKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, ElementOfResult where Self : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "sorted",
           "printedName": "sorted()",
-          "declKind": "Func",
-          "usr": "s:STsSL7ElementRpzrlE6sortedSayABGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.Element : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Self.Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSL7ElementRpzrlE6sortedSayABGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence, Self.Element : Comparable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "sorted",
           "printedName": "sorted(by:)",
-          "declKind": "Func",
-          "usr": "s:STsE6sorted2bySay7ElementQzGSbAD_ADtKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Self.Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element, Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -81052,23 +92354,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:STsE6sorted2bySay7ElementQzGSbAD_ADtKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "joined",
           "printedName": "joined(separator:)",
-          "declKind": "Func",
-          "usr": "s:STsSy7ElementRpzrlE6joined9separatorS2S_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence, Self.Element : StringProtocol>",
-          "declAttributes": [
-            "Specialize",
-            "Specialize"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -81083,56 +92388,51 @@
               "hasDefaultArg": true,
               "usr": "s:SS"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:STsSy7ElementRpzrlE6joined9separatorS2S_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Sequence, Self.Element : StringProtocol>",
+          "declAttributes": [
+            "Specialize",
+            "Specialize"
           ]
         },
         {
           "kind": "Function",
           "name": "flatMap",
           "printedName": "flatMap(_:)",
-          "declKind": "Func",
-          "usr": "s:STsE7flatMapySayqd__Gqd__Sg7ElementQzKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, ElementOfResult where Self : Sequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[ElementOfResult]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "ElementOfResult"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> ElementOfResult?",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "ElementOfResult?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "ElementOfResult"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -81146,246 +92446,226 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "flatMap",
-          "printedName": "flatMap(_:)",
+          ],
           "declKind": "Func",
-          "usr": "s:STsE7flatMapySaySSGSS7ElementQzKXEKF",
-          "location": "",
+          "usr": "s:STsE7flatMapySayqd__Gqd__Sg7ElementQzKXEKlF",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : Sequence>",
-          "throwing": true,
+          "genericSig": "<Self, ElementOfResult where Self : Sequence>",
+          "deprecated": true,
           "declAttributes": [
             "Rethrows",
             "Available"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "[String]",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Self.Element) throws -> String",
-              "typeAttributes": [
-                "noescape"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Self.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "Self.Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
+          "throwing": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:ST",
+      "moduleName": "Swift",
+      "genericSig": "<Self.Element == Self.Iterator.Element, Self.Iterator : IteratorProtocol, Self.SubSequence : Sequence, Self.SubSequence == Self.SubSequence.SubSequence, Self.Iterator.Element == Self.SubSequence.Element, Self.SubSequence.Element == Self.SubSequence.Iterator.Element>"
     },
     {
       "kind": "TypeDecl",
       "name": "IteratorSequence",
       "printedName": "IteratorSequence",
-      "declKind": "Struct",
-      "usr": "s:s16IteratorSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : IteratorProtocol>",
-      "conformingProtocols": [
-        "IteratorProtocol",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s16IteratorSequenceVyAByxGxcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : IteratorProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "IteratorSequence",
               "printedName": "IteratorSequence<Base>",
-              "usr": "s:s16IteratorSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "usr": "s:s16IteratorSequenceV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Base"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s16IteratorSequenceVyAByxGxcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : IteratorProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s16IteratorSequenceV4next7ElementQzSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : IteratorProtocol>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Base.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16IteratorSequenceV4next7ElementQzSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : IteratorProtocol>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s16IteratorSequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : IteratorProtocol>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s16IteratorSequenceV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : IteratorProtocol>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s16IteratorSequenceV0A0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : IteratorProtocol>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "IteratorSequence",
               "printedName": "IteratorSequence<Base>",
-              "usr": "s:s16IteratorSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "usr": "s:s16IteratorSequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s16IteratorSequenceV0A0a",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : IteratorProtocol>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s16IteratorSequenceV03SubB0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : IteratorProtocol>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Base.Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s16IteratorSequenceV03SubB0a",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : IteratorProtocol>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s16IteratorSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<Base where Base : IteratorProtocol>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol",
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "_SequenceWrapper",
       "printedName": "_SequenceWrapper",
-      "declKind": "Protocol",
-      "usr": "s:s16_SequenceWrapperP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Sequence, Self.Base : Sequence, Self.Element == Self.Base.Element>",
-      "conformingProtocols": [
-        "Sequence"
-      ],
-      "declAttributes": [
-        "ShowInInterface"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Base",
+          "printedName": "Base",
+          "declKind": "AssociatedType",
+          "usr": "s:s16_SequenceWrapperP4BaseQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "Iterator",
+          "printedName": "Iterator",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Base.Iterator"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:s16_SequenceWrapperP8IteratorQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Base.SubSequence"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:s16_SequenceWrapperP03SubA0Qa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s16_SequenceWrapperPsE19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -81397,11 +92677,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s16_SequenceWrapperPsE19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : _SequenceWrapper>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -81409,65 +92684,61 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s16_SequenceWrapperPsE19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : _SequenceWrapper>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s16_SequenceWrapperPsE19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPs4Base_8IteratorQZADRtzrlE04makeD0AFyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper, Self.Iterator == Self.Base.Iterator>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Iterator"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPs4Base_8IteratorQZADRtzrlE04makeD0AFyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : _SequenceWrapper, Self.Iterator == Self.Base.Iterator>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPsE3mapySayqd__Gqd__7ElementQzKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, T where Self : _SequenceWrapper>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[T]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> T",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -81486,45 +92757,44 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPsE3mapySayqd__Gqd__7ElementQzKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, T where Self : _SequenceWrapper>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPsE6filterySay7ElementQzGSbAEKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Self.Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -81544,24 +92814,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPsE6filterySay7ElementQzGSbAEKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : _SequenceWrapper>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "forEach",
           "printedName": "forEach(_:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPsE7forEachyyy7ElementQzKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -81572,9 +92844,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -81600,22 +92869,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPsE7forEachyyy7ElementQzKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : _SequenceWrapper>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE9dropFirstyAFSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -81628,20 +92901,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE9dropFirstyAFSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE8dropLastyAFSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -81654,20 +92926,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE8dropLastyAFSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(_:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE6prefixyAFSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -81680,20 +92951,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE6prefixyAFSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE6suffixyAFSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -81706,22 +92976,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE6suffixyAFSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE4drop5whileAFSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -81732,9 +92999,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -81754,24 +93018,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE4drop5whileAFSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE6prefix5whileAFSb7ElementQzKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -81782,9 +93048,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -81804,37 +93067,39 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE6prefix5whileAFSb7ElementQzKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(maxSplits:omittingEmptySubsequences:whereSeparator:)",
-          "declKind": "Func",
-          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAFGSi_S2b7ElementQzKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Self.SubSequence]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.SubSequence"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -81852,9 +93117,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -81874,52 +93136,73 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16_SequenceWrapperPs4Base_03SubA0QZADRtzrlE5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAFGSi_S2b7ElementQzKXEtKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : _SequenceWrapper, Self.SubSequence == Self.Base.SubSequence>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s16_SequenceWrapperP",
+      "moduleName": "Swift",
+      "genericSig": "<Self : Sequence, Self.Base : Sequence, Self.Element == Self.Base.Element>",
+      "declAttributes": [
+        "ShowInInterface"
+      ],
+      "conformingProtocols": [
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Set",
       "printedName": "Set",
-      "declKind": "Struct",
-      "usr": "s:Sh",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element where Element : Hashable>",
-      "conformingProtocols": [
-        "Encodable",
-        "Decodable",
-        "ExpressibleByArrayLiteral",
-        "Sequence",
-        "Collection",
-        "Equatable",
-        "Hashable",
-        "_HasCustomAnyHashableRepresentation",
-        "SetAlgebra",
-        "CustomStringConvertible",
-        "CustomDebugStringConvertible",
-        "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(minimumCapacity:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:Sh"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sh15minimumCapacityShyxGSi_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>"
+        },
+        {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:ShsSERzrlE6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Encodable, Element : Hashable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -81932,34 +93215,30 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:ShsSERzrlE6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Encodable, Element : Hashable>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:ShsSeRzrlE4fromShyxGs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Decodable, Element : Hashable>",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             },
             {
               "kind": "TypeNominal",
@@ -81967,182 +93246,35 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "insert",
-          "printedName": "insert(_:)",
-          "declKind": "Func",
-          "usr": "s:Shss11AnyHashableVRszrlE6insertySb8inserted_qd__17memberAfterInserttqd__SHRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, ConcreteElement where Element == AnyHashable, ConcreteElement : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(inserted: Bool, memberAfterInsert: ConcreteElement)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Bool",
-                  "printedName": "Bool",
-                  "usr": "s:Sb"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "ConcreteElement"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "ConcreteElement"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "update",
-          "printedName": "update(with:)",
-          "declKind": "Func",
-          "usr": "s:Shss11AnyHashableVRszrlE6update4withqd__Sgqd___tSHRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, ConcreteElement where Element == AnyHashable, ConcreteElement : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "ConcreteElement?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "ConcreteElement"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "ConcreteElement"
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "remove",
-          "printedName": "remove(_:)",
-          "declKind": "Func",
-          "usr": "s:Shss11AnyHashableVRszrlE6removeyqd__Sgqd__SHRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, ConcreteElement where Element == AnyHashable, ConcreteElement : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "ConcreteElement?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "ConcreteElement"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "ConcreteElement"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(minimumCapacity:)",
           "declKind": "Constructor",
-          "usr": "s:Sh15minimumCapacityShyxGSi_tcfc",
-          "location": "",
+          "usr": "s:ShsSeRzrlE4fromShyxGs7Decoder_p_tKcfc",
           "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Set",
-              "printedName": "Set<Element>",
-              "usr": "s:Sh",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
+          "genericSig": "<Element where Element : Decodable, Element : Hashable>",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(arrayLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Sh12arrayLiteralShyxGxd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             },
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Set<Element>.Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -82156,68 +93288,60 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sh12arrayLiteralShyxGxd_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "ArrayLiteralElement",
           "printedName": "ArrayLiteralElement",
-          "declKind": "TypeAlias",
-          "usr": "s:Sh19ArrayLiteralElementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sh19ArrayLiteralElementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Iterator",
+              "printedName": "Set<Element>.Iterator",
+              "usr": "s:Sh8IteratorV"
+            }
+          ],
           "declKind": "Func",
-          "usr": "s:Sh12makeIterators03SetB0VyxGyF",
-          "location": "",
+          "usr": "s:Sh12makeIteratorSh0B0Vyx_GyF",
           "moduleName": "Swift",
           "genericSig": "<Element where Element : Hashable>",
           "declAttributes": [
             "Inline",
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "SetIterator",
-              "printedName": "SetIterator<Element>",
-              "usr": "s:s11SetIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
           ]
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh8containsySbxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -82237,19 +93361,84 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh8containsySbxF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
+          "kind": "Function",
+          "name": "filter",
+          "printedName": "filter(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:Sh"
+            },
+            {
+              "kind": "TypeFunc",
+              "name": "Function",
+              "printedName": "(Set<Element>.Element) throws -> Bool",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Paren",
+                  "printedName": "(Set<Element>.Element)",
+                  "children": [
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Element",
+                      "printedName": "Set<Element>.Element",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
+                        }
+                      ]
+                    }
+                  ]
+                }
+              ],
+              "typeAttributes": [
+                "noescape"
+              ]
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh6filteryShyxGSbxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Rethrows",
+            "Available",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:Sh10startIndexSh0B0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -82261,11 +93450,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh10startIndexSh0B0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -82273,21 +93457,24 @@
                   "printedName": "Set<Element>.Index",
                   "usr": "s:Sh5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh10startIndexSh0B0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh10startIndexSh0B0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:Sh8endIndexSh0B0Vyx_Gvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -82299,11 +93486,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh8endIndexSh0B0Vyx_Gvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -82311,22 +93493,49 @@
                   "printedName": "Set<Element>.Index",
                   "usr": "s:Sh5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh8endIndexSh0B0Vyx_Gvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh8endIndexSh0B0Vyx_Gvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Set<Element>.Index",
+              "usr": "s:Sh5IndexV"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:ShyxSh5IndexVyx_Gcip",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:Sh5index5afterSh5IndexVyx_GAE_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -82340,26 +93549,49 @@
               "printedName": "Set<Element>.Index",
               "usr": "s:Sh5IndexV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh5index5afterSh5IndexVyx_GAE_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "formIndex",
+          "printedName": "formIndex(after:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "Set<Element>.Index",
+              "usr": "s:Sh5IndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh9formIndex5afterySh0B0Vyx_Gz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "firstIndex",
           "printedName": "firstIndex(of:)",
-          "declKind": "Func",
-          "usr": "s:Sh10firstIndex2ofSh0B0Vyx_GSgx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Set<Element>.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -82367,7 +93599,8 @@
                   "printedName": "Set<Element>.Index",
                   "usr": "s:Sh5IndexV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -82381,19 +93614,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh10firstIndex2ofSh0B0Vyx_GSgx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:Sh5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -82405,11 +93638,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -82417,21 +93645,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "isEmpty",
           "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:Sh7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -82443,11 +93674,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -82455,182 +93681,204 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "first",
           "printedName": "first",
-          "declKind": "Var",
-          "usr": "s:Sh5firstxSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh5firstxSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh5firstxSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh5firstxSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:Sh7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sh7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:Sh8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "SetIterator",
-              "printedName": "SetIterator<Element>",
-              "usr": "s:s11SetIteratorV",
+              "name": "Slice",
+              "printedName": "Slice<Set<Element>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Set",
+                  "printedName": "Set<Element>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Element"
+                    }
+                  ],
+                  "usr": "s:Sh"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sh11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "implicit": true
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "Indices",
+          "printedName": "Indices",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DefaultIndices",
+              "printedName": "DefaultIndices<Set<Element>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Set",
+                  "printedName": "Set<Element>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Element"
+                    }
+                  ],
+                  "usr": "s:Sh"
+                }
+              ],
+              "usr": "s:SI"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sh7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "implicit": true
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Set",
+              "printedName": "Set<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:Sh11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "children": [
+              ],
+              "usr": "s:Sh"
+            },
             {
               "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<Set<Element>>",
-              "usr": "s:s5SliceV",
+              "name": "Set",
+              "printedName": "Set<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Set",
-                  "printedName": "Set<Element>",
-                  "usr": "s:Sh",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:Sh7Indicesa",
-          "location": "",
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh2eeoiySbShyxG_ABtFZ",
           "moduleName": "Swift",
           "genericSig": "<Element where Element : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DefaultIndices",
-              "printedName": "DefaultIndices<Set<Element>>",
-              "usr": "s:SI",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Set",
-                  "printedName": "Set<Element>",
-                  "usr": "s:Sh",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:Sh4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -82643,16 +93891,19 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Sh9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -82664,11 +93915,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -82676,24 +93922,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh6insertySb8inserted_x17memberAfterInserttxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -82732,28 +93977,26 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh6insertySb8inserted_x17memberAfterInserttxnF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "update",
           "printedName": "update(with:)",
-          "declKind": "Func",
-          "usr": "s:Sh6update4withxSgx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Set<Element>.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -82767,7 +94010,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -82781,28 +94025,26 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh6update4withxSgxn_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "remove",
           "printedName": "remove(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh6removeyxSgxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Set<Element>.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -82816,7 +94058,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -82830,22 +94073,21 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh6removeyxSgxF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "remove",
           "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:Sh6remove2atxSh5IndexVyx_G_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -82865,21 +94107,21 @@
               "printedName": "Set<Element>.Index",
               "usr": "s:Sh5IndexV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh6remove2atxSh5IndexVyx_G_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeAll",
           "printedName": "removeAll(keepingCapacity:)",
-          "declKind": "Func",
-          "usr": "s:Sh9removeAll15keepingCapacityySb_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -82893,22 +94135,20 @@
               "hasDefaultArg": true,
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh9removeAll15keepingCapacityySb_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeFirst",
           "printedName": "removeFirst()",
-          "declKind": "Func",
-          "usr": "s:Sh11removeFirstxyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -82922,81 +94162,80 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh11removeFirstxyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:S2hyxGycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:S2hyxGycfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:ShyShyxGqd__c7ElementQyd__RszSTRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, Source where Element : Hashable, Element == Source.Element, Source : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Source"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:ShyShyxGqd__nc7ElementQyd__RszSTRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Element, Source where Element : Hashable, Element == Source.Element, Source : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "isSubset",
           "printedName": "isSubset(of:)",
-          "declKind": "Func",
-          "usr": "s:Sh8isSubset2ofSbqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -83009,20 +94248,19 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh8isSubset2ofSbqd___t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "isStrictSubset",
           "printedName": "isStrictSubset(of:)",
-          "declKind": "Func",
-          "usr": "s:Sh14isStrictSubset2ofSbqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -83035,20 +94273,19 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh14isStrictSubset2ofSbqd___t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "isSuperset",
           "printedName": "isSuperset(of:)",
-          "declKind": "Func",
-          "usr": "s:Sh10isSuperset2ofSbqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -83061,20 +94298,19 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh10isSuperset2ofSbqd__n_t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "isStrictSuperset",
           "printedName": "isStrictSuperset(of:)",
-          "declKind": "Func",
-          "usr": "s:Sh16isStrictSuperset2ofSbqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -83087,20 +94323,19 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh16isStrictSuperset2ofSbqd___t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "isDisjoint",
           "printedName": "isDisjoint(with:)",
-          "declKind": "Func",
-          "usr": "s:Sh10isDisjoint4withSbqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -83113,26 +94348,24 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh10isDisjoint4withSbqd___t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "union",
           "printedName": "union(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh5unionyShyxGqd__7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -83146,28 +94379,27 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh5unionyShyxGqd__n7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formUnion",
           "printedName": "formUnion(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh9formUnionyyqd__7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -83179,26 +94411,25 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "subtracting",
-          "printedName": "subtracting(_:)",
+          ],
           "declKind": "Func",
-          "usr": "s:Sh11subtractingyShyxGqd__7ElementQyd__RszSTRd__lF",
-          "location": "",
+          "usr": "s:Sh9formUnionyyqd__n7ElementQyd__RszSTRd__lF",
           "moduleName": "Swift",
           "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
           "declAttributes": [
             "Inlinable"
           ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "subtracting",
+          "printedName": "subtracting(_:)",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -83212,28 +94443,27 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh11subtractingyShyxGqd__7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "subtract",
           "printedName": "subtract(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh8subtractyyqd__7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -83245,26 +94475,25 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "intersection",
-          "printedName": "intersection(_:)",
+          ],
           "declKind": "Func",
-          "usr": "s:Sh12intersectionyShyxGqd__7ElementQyd__RszSTRd__lF",
-          "location": "",
+          "usr": "s:Sh8subtractyyqd__7ElementQyd__RszSTRd__lF",
           "moduleName": "Swift",
           "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
           "declAttributes": [
             "Inlinable"
           ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "intersection",
+          "printedName": "intersection(_:)",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -83278,28 +94507,27 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh12intersectionyShyxGqd__7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIntersection",
           "printedName": "formIntersection(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh16formIntersectionyyqd__7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -83311,26 +94539,25 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "symmetricDifference",
-          "printedName": "symmetricDifference(_:)",
+          ],
           "declKind": "Func",
-          "usr": "s:Sh19symmetricDifferenceyShyxGqd__7ElementQyd__RszSTRd__lF",
-          "location": "",
+          "usr": "s:Sh16formIntersectionyyqd__7ElementQyd__RszSTRd__lF",
           "moduleName": "Swift",
           "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
           "declAttributes": [
             "Inlinable"
           ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "symmetricDifference",
+          "printedName": "symmetricDifference(_:)",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -83344,28 +94571,27 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh19symmetricDifferenceyShyxGqd__n7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formSymmetricDifference",
           "printedName": "formSymmetricDifference(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh23formSymmetricDifferenceyyqd__7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -83377,19 +94603,20 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh23formSymmetricDifferenceyyqd__n7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element : Hashable, Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:Sh11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -83401,11 +94628,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -83413,18 +94635,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh11descriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh11descriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Sh16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -83436,11 +94661,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -83448,23 +94668,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "subtract",
           "printedName": "subtract(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh8subtractyyShyxGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -83475,7 +94693,6 @@
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -83489,22 +94706,23 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "isSubset",
-          "printedName": "isSubset(of:)",
+          ],
           "declKind": "Func",
-          "usr": "s:Sh8isSubset2ofSbShyxG_tF",
-          "location": "",
+          "usr": "s:Sh8subtractyyShyxGF",
           "moduleName": "Swift",
           "genericSig": "<Element where Element : Hashable>",
           "declAttributes": [
             "Inlinable"
           ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "isSubset",
+          "printedName": "isSubset(of:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -83516,7 +94734,6 @@
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -83530,22 +94747,22 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh8isSubset2ofSbShyxG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "isSuperset",
           "printedName": "isSuperset(of:)",
-          "declKind": "Func",
-          "usr": "s:Sh10isSuperset2ofSbShyxG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -83557,7 +94774,6 @@
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -83571,22 +94787,22 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh10isSuperset2ofSbShyxG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "isDisjoint",
           "printedName": "isDisjoint(with:)",
-          "declKind": "Func",
-          "usr": "s:Sh10isDisjoint4withSbShyxG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -83598,7 +94814,6 @@
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -83612,28 +94827,27 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh10isDisjoint4withSbShyxG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "subtracting",
           "printedName": "subtracting(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh11subtractingyShyxGABF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -83647,13 +94861,13 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             },
             {
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -83667,22 +94881,22 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh11subtractingyShyxGABF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "isStrictSuperset",
           "printedName": "isStrictSuperset(of:)",
-          "declKind": "Func",
-          "usr": "s:Sh16isStrictSuperset2ofSbShyxG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -83694,7 +94908,6 @@
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -83708,22 +94921,22 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh16isStrictSuperset2ofSbShyxG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "isStrictSubset",
           "printedName": "isStrictSubset(of:)",
-          "declKind": "Func",
-          "usr": "s:Sh14isStrictSubset2ofSbShyxG_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -83735,7 +94948,6 @@
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -83749,28 +94961,27 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh14isStrictSubset2ofSbShyxG_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "intersection",
           "printedName": "intersection(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh12intersectionyShyxGABF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -83784,13 +94995,13 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             },
             {
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -83804,23 +95015,22 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh12intersectionyShyxGABF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formSymmetricDifference",
           "printedName": "formSymmetricDifference(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh23formSymmetricDifferenceyyShyxGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -83831,7 +95041,6 @@
               "kind": "TypeNominal",
               "name": "Set",
               "printedName": "Set<Set<Element>.Element>",
-              "usr": "s:Sh",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -83845,75 +95054,94 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sh"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh23formSymmetricDifferenceyyShyxGnF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "TypeDecl",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "Struct",
-          "usr": "s:Sh5IndexV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "conformingProtocols": [
-            "Comparable",
-            "Hashable",
-            "Equatable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
-              "kind": "Var",
-              "name": "hashValue",
-              "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:Sh5IndexV9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
               "children": [
                 {
                   "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
                 },
                 {
-                  "kind": "Getter",
-                  "name": "_",
-                  "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Sh5IndexV9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<Element where Element : Hashable>",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Set<Element>.Index",
+                  "usr": "s:Sh5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Set<Element>.Index",
+                  "usr": "s:Sh5IndexV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Sh5IndexV2eeoiySbAByx_G_ADtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Set<Element>.Index",
+                  "usr": "s:Sh5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "Set<Element>.Index",
+                  "usr": "s:Sh5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Sh5IndexV1loiySbAByx_G_ADtFZ",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:Sh5IndexV4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -83926,18 +95154,162 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:Sh5IndexV4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>"
+            },
+            {
+              "kind": "Var",
+              "name": "hashValue",
+              "printedName": "hashValue",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Sh5IndexV9hashValueSivg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Element where Element : Hashable>",
+                  "implicit": true
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Sh5IndexV9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:Sh5IndexV",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "Equatable",
+            "Comparable",
+            "Hashable"
+          ]
+        },
+        {
+          "kind": "TypeDecl",
+          "name": "Iterator",
+          "printedName": "Iterator",
+          "children": [
+            {
+              "kind": "Function",
+              "name": "next",
+              "printedName": "next()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Optional",
+                  "printedName": "Element?",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Element"
+                    }
+                  ],
+                  "usr": "s:Sq"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:Sh8IteratorV4nextxSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>",
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
+              ],
+              "mutating": true
+            },
+            {
+              "kind": "TypeAlias",
+              "name": "Element",
+              "printedName": "Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Sh8IteratorV7Elementa",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>",
+              "implicit": true
+            },
+            {
+              "kind": "Var",
+              "name": "customMirror",
+              "printedName": "customMirror",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Mirror",
+                  "printedName": "Mirror",
+                  "usr": "s:s6MirrorV"
+                },
+                {
+                  "kind": "Getter",
+                  "name": "_",
+                  "printedName": "_()",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Mirror",
+                      "printedName": "Mirror",
+                      "usr": "s:s6MirrorV"
+                    }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Sh8IteratorV12customMirrors0C0Vvg",
+                  "moduleName": "Swift",
+                  "genericSig": "<Element where Element : Hashable>"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Sh8IteratorV12customMirrors0C0Vvp",
+              "moduleName": "Swift"
+            }
+          ],
+          "declKind": "Struct",
+          "usr": "s:Sh8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "CustomReflectable"
           ]
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Sh12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -83949,11 +95321,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -83961,29 +95328,26 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh12customMirrors0B0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh12customMirrors0B0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "popFirst",
           "printedName": "popFirst()",
-          "declKind": "Func",
-          "usr": "s:Sh8popFirstxSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Set<Element>.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -83997,21 +95361,23 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh8popFirstxSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Var",
           "name": "capacity",
           "printedName": "capacity",
-          "declKind": "Var",
-          "usr": "s:Sh8capacitySivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -84023,11 +95389,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sh8capacitySivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -84035,23 +95396,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sh8capacitySivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Hashable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sh8capacitySivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "reserveCapacity",
           "printedName": "reserveCapacity(_:)",
-          "declKind": "Func",
-          "usr": "s:Sh15reserveCapacityyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -84064,50 +95426,22 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sh15reserveCapacityyySiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Hashable>",
+          "mutating": true
         },
         {
           "kind": "Function",
-          "name": "filter",
-          "printedName": "filter(_:obsoletedInSwift4:)",
-          "declKind": "Func",
-          "usr": "s:Sh6filter_17obsoletedInSwift4SayxGSbxKXE_yttKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Available"
-          ],
+          "name": "insert",
+          "printedName": "insert(_:)",
           "children": [
             {
               "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "[Set<Element>.Element]",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "Set<Element>.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "τ_0_0"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeFunc",
-              "name": "Function",
-              "printedName": "(Set<Element>.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
+              "name": "Tuple",
+              "printedName": "(inserted: Bool, memberAfterInsert: ConcreteElement)",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -84117,44 +95451,121 @@
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Paren",
-                  "printedName": "(Set<Element>.Element)",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "Set<Element>.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "GenericTypeParam",
-                          "printedName": "τ_0_0"
-                        }
-                      ]
-                    }
-                  ]
+                  "name": "GenericTypeParam",
+                  "printedName": "ConcreteElement"
                 }
               ]
             },
             {
               "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()",
-              "hasDefaultArg": true
+              "name": "GenericTypeParam",
+              "printedName": "ConcreteElement"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Shss11AnyHashableVRszrlE6insertySb8inserted_qd__17memberAfterInserttqd__nSHRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, ConcreteElement where Element == AnyHashable, ConcreteElement : Hashable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "update",
+          "printedName": "update(with:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "ConcreteElement?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "ConcreteElement"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "ConcreteElement"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Shss11AnyHashableVRszrlE6update4withqd__Sgqd__n_tSHRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, ConcreteElement where Element == AnyHashable, ConcreteElement : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "remove",
+          "printedName": "remove(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "ConcreteElement?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "ConcreteElement"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "ConcreteElement"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Shss11AnyHashableVRszrlE6removeyqd__Sgqd__SHRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, ConcreteElement where Element == AnyHashable, ConcreteElement : Hashable>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:Sh",
+      "moduleName": "Swift",
+      "genericSig": "<Element where Element : Hashable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Encodable",
+        "Decodable",
+        "ExpressibleByArrayLiteral",
+        "Sequence",
+        "Collection",
+        "Equatable",
+        "Hashable",
+        "_HasCustomAnyHashableRepresentation",
+        "SetAlgebra",
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible",
+        "CustomReflectable"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "SetIndex",
       "printedName": "SetIndex",
-      "declKind": "TypeAlias",
-      "usr": "s:s8SetIndexa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element where Element : Hashable>",
       "children": [
         {
           "kind": "TypeNominal",
@@ -84162,149 +95573,64 @@
           "printedName": "Set<Element>.Index",
           "usr": "s:Sh5IndexV"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s8SetIndexa",
+      "moduleName": "Swift",
+      "genericSig": "<Element where Element : Hashable>"
     },
     {
-      "kind": "TypeDecl",
+      "kind": "TypeAlias",
       "name": "SetIterator",
       "printedName": "SetIterator",
-      "declKind": "Struct",
-      "usr": "s:s11SetIteratorV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element where Element : Hashable>",
-      "conformingProtocols": [
-        "IteratorProtocol",
-        "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
-          "kind": "Function",
-          "name": "next",
-          "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s11SetIteratorV4nextxSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s11SetIteratorV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Hashable>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "customMirror",
-          "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s11SetIteratorV12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Mirror",
-              "printedName": "Mirror",
-              "usr": "s:s6MirrorV"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11SetIteratorV12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Hashable>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Mirror",
-                  "printedName": "Mirror",
-                  "usr": "s:s6MirrorV"
-                }
-              ]
-            }
-          ]
+          "kind": "TypeNominal",
+          "name": "Iterator",
+          "printedName": "Set<Element>.Iterator",
+          "usr": "s:Sh8IteratorV"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s11SetIteratora",
+      "moduleName": "Swift",
+      "genericSig": "<Element where Element : Hashable>"
     },
     {
       "kind": "TypeDecl",
       "name": "SetAlgebra",
       "printedName": "SetAlgebra",
-      "declKind": "Protocol",
-      "usr": "s:s10SetAlgebraP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Equatable, Self : ExpressibleByArrayLiteral>",
-      "conformingProtocols": [
-        "Equatable",
-        "ExpressibleByArrayLiteral"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Element",
+          "printedName": "Element",
+          "declKind": "AssociatedType",
+          "usr": "s:s10SetAlgebraP7ElementQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s10SetAlgebraPxycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s10SetAlgebraPxycfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "contains",
           "printedName": "contains(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP8containsySb7ElementQzF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -84317,17 +95643,17 @@
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP8containsySb7ElementQzF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "union",
           "printedName": "union(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP5unionyxxnF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -84339,17 +95665,17 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP5unionyxxnF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "intersection",
           "printedName": "intersection(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP12intersectionyxxnF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -84361,17 +95687,17 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP12intersectionyxxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "symmetricDifference",
           "printedName": "symmetricDifference(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP19symmetricDifferenceyxxnF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -84383,21 +95709,17 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP19symmetricDifferenceyxxnF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP6insertySb8inserted_7ElementQz17memberAfterInserttAFnF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -84422,86 +95744,89 @@
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP6insertySb8inserted_7ElementQz17memberAfterInserttAFnF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "protocolReq": true,
+          "declAttributes": [
+            "DiscardableResult"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "remove",
           "printedName": "remove(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP6removey7ElementQzSgAEF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP6removey7ElementQzSgAEF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "protocolReq": true,
+          "declAttributes": [
+            "DiscardableResult"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "update",
           "printedName": "update(with:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP6update4with7ElementQzSgAFn_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Self.Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Self.Element"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP6update4with7ElementQzSgAFn_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "protocolReq": true,
+          "declAttributes": [
+            "DiscardableResult"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "formUnion",
           "printedName": "formUnion(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP9formUnionyyxnF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -84513,18 +95838,18 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP9formUnionyyxnF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "formIntersection",
           "printedName": "formIntersection(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP16formIntersectionyyxnF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -84536,18 +95861,18 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP16formIntersectionyyxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "formSymmetricDifference",
           "printedName": "formSymmetricDifference(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP23formSymmetricDifferenceyyxnF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -84559,17 +95884,18 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP23formSymmetricDifferenceyyxnF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "subtracting",
           "printedName": "subtracting(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP11subtractingyxxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -84581,17 +95907,17 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP11subtractingyxxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "isSubset",
           "printedName": "isSubset(of:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP8isSubset2ofSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -84604,17 +95930,17 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP8isSubset2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "isDisjoint",
           "printedName": "isDisjoint(with:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP10isDisjoint4withSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -84627,17 +95953,17 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP10isDisjoint4withSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "isSuperset",
           "printedName": "isSuperset(of:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP10isSuperset2ofSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -84650,16 +95976,17 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP10isSuperset2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "isEmpty",
           "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:s10SetAlgebraP7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -84671,11 +95998,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10SetAlgebraP7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : SetAlgebra>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -84683,42 +96005,44 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10SetAlgebraP7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : SetAlgebra>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s10SetAlgebraP7isEmptySbvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "S"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s10SetAlgebraPyxqd__ncSTRd__7ElementQyd__ACRtzlufc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Self, S where Self : SetAlgebra, S : Sequence, Self.Element == S.Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Self"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
-          ]
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "subtract",
           "printedName": "subtract(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraP8subtractyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -84730,20 +96054,18 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraP8subtractyyxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s10SetAlgebraPsEyxqd__cSTRd__7ElementQyd__ACRtzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, S where Self : SetAlgebra, S : Sequence, Self.Element == S.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -84755,21 +96077,19 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s10SetAlgebraPsEyxqd__ncSTRd__7ElementQyd__ACRtzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, S where Self : SetAlgebra, S : Sequence, Self.Element == S.Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "subtract",
           "printedName": "subtract(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraPsE8subtractyyxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -84781,20 +96101,20 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraPsE8subtractyyxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "isSubset",
           "printedName": "isSubset(of:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraPsE8isSubset2ofSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -84807,20 +96127,19 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraPsE8isSubset2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "isSuperset",
           "printedName": "isSuperset(of:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraPsE10isSuperset2ofSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -84833,20 +96152,19 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraPsE10isSuperset2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "isDisjoint",
           "printedName": "isDisjoint(with:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraPsE10isDisjoint4withSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -84859,20 +96177,19 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraPsE10isDisjoint4withSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "subtracting",
           "printedName": "subtracting(_:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraPsE11subtractingyxxF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -84884,19 +96201,19 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraPsE11subtractingyxxF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "isEmpty",
           "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:s10SetAlgebraPsE7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -84908,11 +96225,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s10SetAlgebraPsE7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : SetAlgebra>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -84920,22 +96232,24 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s10SetAlgebraPsE7isEmptySbvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : SetAlgebra>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s10SetAlgebraPsE7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "isStrictSuperset",
           "printedName": "isStrictSuperset(of:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraPsE16isStrictSuperset2ofSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -84948,20 +96262,19 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraPsE16isStrictSuperset2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "isStrictSubset",
           "printedName": "isStrictSubset(of:)",
-          "declKind": "Func",
-          "usr": "s:s10SetAlgebraPsE14isStrictSubset2ofSbx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -84974,20 +96287,19 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s10SetAlgebraPsE14isStrictSubset2ofSbx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(arrayLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s10SetAlgebraPs7ElementQz012ArrayLiteralC0RtzrlE05arrayE0xAFd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : SetAlgebra, Self.ArrayLiteralElement == Self.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -84998,67 +96310,56 @@
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Self.Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s10SetAlgebraPs7ElementQz012ArrayLiteralC0RtzrlE05arrayE0xAFd_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : SetAlgebra, Self.ArrayLiteralElement == Self.Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s10SetAlgebraP",
+      "moduleName": "Swift",
+      "genericSig": "<Self : Equatable, Self : ExpressibleByArrayLiteral>",
+      "conformingProtocols": [
+        "Equatable",
+        "ExpressibleByArrayLiteral"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Slice",
       "printedName": "Slice",
-      "declKind": "Struct",
-      "usr": "s:s5SliceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Collection>",
-      "conformingProtocols": [
-        "LazySequenceProtocol",
-        "LazyCollectionProtocol",
-        "Collection",
-        "Sequence",
-        "BidirectionalCollection",
-        "MutableCollection",
-        "RandomAccessCollection",
-        "RangeReplaceableCollection"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(base:bounds:)",
-          "declKind": "Constructor",
-          "usr": "s:s5SliceV4base6boundsAByxGx_Sny5IndexQzGtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<Base>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             },
             {
               "kind": "TypeNominal",
@@ -85069,28 +96370,28 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Base.Index>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Index"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5SliceV4base6boundsAByxGx_Sny5IndexQzGtcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "base",
           "printedName": "base",
-          "declKind": "Var",
-          "usr": "s:s5SliceV4basexvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -85101,166 +96402,159 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5SliceV4basexvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5SliceV4basexvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5SliceV4basexvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Elements",
           "printedName": "Elements",
-          "declKind": "TypeAlias",
-          "usr": "s:s5SliceVss22LazyCollectionProtocolRzrlE8Elementsa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : LazyCollectionProtocol>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<Base>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5SliceVss22LazyCollectionProtocolRzrlE8Elementsa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : LazyCollectionProtocol>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s5SliceV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Index"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5SliceV5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s5SliceV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Indices"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5SliceV7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s5SliceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Base.Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5SliceV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s5SliceV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<Base>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5SliceV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s5SliceV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "IndexingIterator",
               "printedName": "IndexingIterator<Slice<Base>>",
-              "usr": "s:s16IndexingIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Slice",
                   "printedName": "Slice<Base>",
-                  "usr": "s:s5SliceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Base"
                     }
-                  ]
+                  ],
+                  "usr": "s:s5SliceV"
                 }
-              ]
+              ],
+              "usr": "s:s16IndexingIteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s5SliceV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>"
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s5SliceV10startIndex0C0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -85271,32 +96565,30 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5SliceV10startIndex0C0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Index"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5SliceV10startIndex0C0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5SliceV10startIndex0C0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s5SliceV8endIndex0C0Qzvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -85307,29 +96599,108 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5SliceV8endIndex0C0Qzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Index"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5SliceV8endIndex0C0Qzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s5SliceV8endIndex0C0Qzvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Base.Element"
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "Slice<Base>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
               ]
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s5SliceVy7ElementQz5IndexQzcip",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<Base>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Base"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Slice<Base>.Index>",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "Slice<Base>.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Index"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s5SliceVyAByxGSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:s5SliceV7indices7IndicesQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -85340,33 +96711,27 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s5SliceV7indices7IndicesQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Base where Base : Collection>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Base.Indices"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s5SliceV7indices7IndicesQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Base where Base : Collection>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s5SliceV7indices7IndicesQzvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceV5index5after5IndexQzAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -85392,20 +96757,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceV5index5after5IndexQzAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceV9formIndex5aftery0C0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -85424,20 +96788,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceV9formIndex5aftery0C0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceV5index_8offsetBy5IndexQzAF_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -85469,26 +96832,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceV5index_8offsetBy5IndexQzAF_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceV5index_8offsetBy07limitedD05IndexQzSgAG_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Slice<Base>.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -85502,7 +96863,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -85534,20 +96896,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceV5index_8offsetBy07limitedD05IndexQzSgAG_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceV8distance4from2toSi5IndexQz_AGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -85579,20 +96940,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceV8distance4from2toSi5IndexQz_AGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSKRzrlE5index6before5IndexQzAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -85618,20 +96978,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSKRzrlE5index6before5IndexQzAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSKRzrlE9formIndex6beforey0C0Qzz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -85650,61 +97009,139 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSKRzrlE9formIndex6beforey0C0Qzz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s5SliceVsSmRzrlEAByxGycfc",
-          "location": "",
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Base.Element"
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "Slice<Base>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "DependentMember",
+                  "printedName": "τ_0_0.Index"
+                }
+              ]
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s5SliceVsSMRzrlEy7ElementQz5IndexQzcip",
           "moduleName": "Swift",
-          "genericSig": "<Base where Base : RangeReplaceableCollection>",
+          "genericSig": "<Base where Base : MutableCollection>",
           "declAttributes": [
             "Inlinable"
           ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<Base>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Slice<Base>.Index>",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "Slice<Base>.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Index"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sn"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s5SliceVsSMRzrlEyAByxGSny5IndexQzGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : MutableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init()",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<Base>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Base"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5SliceVsSmRzrlEAByxGycfc",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(repeating:count:)",
-          "declKind": "Constructor",
-          "usr": "s:s5SliceVsSmRzrlE9repeating5countAByxG7ElementQz_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : RangeReplaceableCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<Base>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             },
             {
               "kind": "TypeNominal",
@@ -85717,100 +97154,96 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5SliceVsSmRzrlE9repeating5countAByxG7ElementQz_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s5SliceVsSmRzrlEyAByxGqd__cSTRd__7ElementQyd__ADRtzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, S where Base : RangeReplaceableCollection, S : Sequence, Base.Element == S.Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<Base>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Base"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s5SliceVsSmRzrlEyAByxGqd__cSTRd__7ElementQyd__ADRtzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<Base, S where Base : RangeReplaceableCollection, S : Sequence, Base.Element == S.Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "replaceSubrange",
           "printedName": "replaceSubrange(_:with:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Slice<Base>.Index>",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "Slice<Base>.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "DependentMember",
+                      "printedName": "τ_0_0.Index"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sn"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            }
+          ],
           "declKind": "Func",
           "usr": "s:s5SliceVsSmRzrlE15replaceSubrange_4withySny5IndexQzG_qd__tSlRd__7ElementQyd__AHRtzlF",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Base, C where Base : RangeReplaceableCollection, C : Collection, Base.Element == C.Element>",
-          "mutating": true,
           "declAttributes": [
             "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Slice<Base>.Index>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "Slice<Base>.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "DependentMember",
-                      "printedName": "τ_0_0.Index"
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "C"
-            }
-          ]
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(_:at:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSmRzrlE6insert_2aty7ElementQz_5IndexQztF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -85834,21 +97267,20 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSmRzrlE6insert_2aty7ElementQz_5IndexQztF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(contentsOf:at:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSmRzrlE6insert10contentsOf2atyqd___5IndexQztSlRd__7ElementQyd__AHRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, S where Base : RangeReplaceableCollection, S : Collection, Base.Element == S.Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -85872,21 +97304,20 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSmRzrlE6insert10contentsOf2atyqd___5IndexQztSlRd__7ElementQyd__AHRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<Base, S where Base : RangeReplaceableCollection, S : Collection, Base.Element == S.Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "remove",
           "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSmRzrlE6remove2at7ElementQz5IndexQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -85905,21 +97336,20 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSmRzrlE6remove2at7ElementQz5IndexQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeSubrange",
           "printedName": "removeSubrange(_:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSmRzrlE14removeSubrangeyySny5IndexQzGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -85930,7 +97360,6 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Slice<Base>.Index>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -85944,23 +97373,23 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSmRzrlE14removeSubrangeyySny5IndexQzGF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "replaceSubrange",
           "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSKRzSmRzrlE15replaceSubrange_4withySny5IndexSlQzG_qd__tSlRd__7ElementQyd__AHSTRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, C where Base : BidirectionalCollection, Base : RangeReplaceableCollection, C : Collection, Base.Element == C.Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -85971,7 +97400,6 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Slice<Base>.Index>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -85985,28 +97413,28 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "C"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSKRzSmRzrlE15replaceSubrange_4withySny5IndexSlQzG_qd__tSlRd__7ElementQyd__AHSTRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<Base, C where Base : BidirectionalCollection, Base : RangeReplaceableCollection, C : Collection, Base.Element == C.Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(_:at:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSKRzSmRzrlE6insert_2aty7ElementSTQz_5IndexSlQztF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection, Base : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -86030,21 +97458,20 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSKRzSmRzrlE6insert_2aty7ElementSTQz_5IndexSlQztF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection, Base : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(contentsOf:at:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSKRzSmRzrlE6insert10contentsOf2atyqd___5IndexSlQztSlRd__7ElementQyd__AHSTRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base, S where Base : BidirectionalCollection, Base : RangeReplaceableCollection, S : Collection, Base.Element == S.Element>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -86068,21 +97495,20 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSKRzSmRzrlE6insert10contentsOf2atyqd___5IndexSlQztSlRd__7ElementQyd__AHSTRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<Base, S where Base : BidirectionalCollection, Base : RangeReplaceableCollection, S : Collection, Base.Element == S.Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "remove",
           "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSKRzSmRzrlE6remove2at7ElementSTQz5IndexSlQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection, Base : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -86101,21 +97527,20 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSKRzSmRzrlE6remove2at7ElementSTQz5IndexSlQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection, Base : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeSubrange",
           "printedName": "removeSubrange(_:)",
-          "declKind": "Func",
-          "usr": "s:s5SliceVsSKRzSmRzrlE14removeSubrangeyySny5IndexSlQzGF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Base where Base : BidirectionalCollection, Base : RangeReplaceableCollection>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -86126,7 +97551,6 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Slice<Base>.Index>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -86140,52 +97564,52 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s5SliceVsSKRzSmRzrlE14removeSubrangeyySny5IndexSlQzGF",
+          "moduleName": "Swift",
+          "genericSig": "<Base where Base : BidirectionalCollection, Base : RangeReplaceableCollection>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s5SliceV",
+      "moduleName": "Swift",
+      "genericSig": "<Base where Base : Collection>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "LazySequenceProtocol",
+        "LazyCollectionProtocol",
+        "Collection",
+        "Sequence",
+        "BidirectionalCollection",
+        "MutableCollection",
+        "RandomAccessCollection",
+        "RangeReplaceableCollection"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "StaticString",
       "printedName": "StaticString",
-      "declKind": "Struct",
-      "usr": "s:s12StaticStringV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "CustomReflectable",
-        "_ExpressibleByBuiltinExtendedGraphemeClusterLiteral",
-        "_ExpressibleByBuiltinStringLiteral",
-        "ExpressibleByUnicodeScalarLiteral",
-        "ExpressibleByExtendedGraphemeClusterLiteral",
-        "ExpressibleByStringLiteral",
-        "CustomStringConvertible",
-        "CustomDebugStringConvertible",
-        "_ExpressibleByBuiltinUnicodeScalarLiteral"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "utf8Start",
           "printedName": "utf8Start",
-          "declKind": "Var",
-          "usr": "s:s12StaticStringV9utf8StartSPys5UInt8VGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<UInt8>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -86193,22 +97617,18 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12StaticStringV9utf8StartSPys5UInt8VGvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafePointer",
                   "printedName": "UnsafePointer<UInt8>",
-                  "usr": "s:SP",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -86216,23 +97636,26 @@
                       "printedName": "UInt8",
                       "usr": "s:s5UInt8V"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV9utf8StartSPys5UInt8VGvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV9utf8StartSPys5UInt8VGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "unicodeScalar",
           "printedName": "unicodeScalar",
-          "declKind": "Var",
-          "usr": "s:s12StaticStringV13unicodeScalars7UnicodeO0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -86244,10 +97667,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12StaticStringV13unicodeScalars7UnicodeO0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -86255,21 +97674,23 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV13unicodeScalars7UnicodeO0D0Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV13unicodeScalars7UnicodeO0D0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "utf8CodeUnitCount",
           "printedName": "utf8CodeUnitCount",
-          "declKind": "Var",
-          "usr": "s:s12StaticStringV17utf8CodeUnitCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -86281,10 +97702,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12StaticStringV17utf8CodeUnitCountSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -86292,21 +97709,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV17utf8CodeUnitCountSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV17utf8CodeUnitCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "hasPointerRepresentation",
           "printedName": "hasPointerRepresentation",
-          "declKind": "Var",
-          "usr": "s:s12StaticStringV24hasPointerRepresentationSbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -86318,10 +97737,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12StaticStringV24hasPointerRepresentationSbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -86329,21 +97744,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV24hasPointerRepresentationSbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV24hasPointerRepresentationSbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "isASCII",
           "printedName": "isASCII",
-          "declKind": "Var",
-          "usr": "s:s12StaticStringV7isASCIISbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -86355,10 +97772,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12StaticStringV7isASCIISbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -86366,22 +97779,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV7isASCIISbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV7isASCIISbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "withUTF8Buffer",
           "printedName": "withUTF8Buffer(_:)",
-          "declKind": "Func",
-          "usr": "s:s12StaticStringV14withUTF8BufferyxxSRys5UInt8VGXElF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<R>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -86392,9 +97806,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafeBufferPointer<UInt8>) -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -86405,13 +97816,11 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafeBufferPointer<UInt8>)",
-                  "usr": "s:SR",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafeBufferPointer",
                       "printedName": "UnsafeBufferPointer<UInt8>",
-                      "usr": "s:SR",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -86419,25 +97828,30 @@
                           "printedName": "UInt8",
                           "usr": "s:s5UInt8V"
                         }
-                      ]
+                      ],
+                      "usr": "s:SR"
                     }
-                  ]
+                  ],
+                  "usr": "s:SR"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s12StaticStringV14withUTF8BufferyxxSRys5UInt8VGXElF",
+          "moduleName": "Swift",
+          "genericSig": "<R>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s12StaticStringVABycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -86445,20 +97859,18 @@
               "printedName": "StaticString",
               "usr": "s:s12StaticStringV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s12StaticStringVABycfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(unicodeScalar:)",
-          "declKind": "Constructor",
-          "usr": "s:s12StaticStringV13unicodeScalarABBi32__tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "UsableFromInline"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -86478,21 +97890,20 @@
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s12StaticStringV13unicodeScalarABBi32__tcfc",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "Transparent",
+            "UsableFromInline"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(unicodeScalarLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s12StaticStringV20unicodeScalarLiteralA2B_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Effects",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -86506,21 +97917,19 @@
               "printedName": "StaticString",
               "usr": "s:s12StaticStringV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s12StaticStringV20unicodeScalarLiteralA2B_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent",
+            "Effects"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(extendedGraphemeClusterLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s12StaticStringV30extendedGraphemeClusterLiteralA2B_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Effects",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -86534,21 +97943,19 @@
               "printedName": "StaticString",
               "usr": "s:s12StaticStringV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s12StaticStringV30extendedGraphemeClusterLiteralA2B_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent",
+            "Effects"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(stringLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s12StaticStringV13stringLiteralA2B_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent",
-            "Effects",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -86562,19 +97969,19 @@
               "printedName": "StaticString",
               "usr": "s:s12StaticStringV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s12StaticStringV13stringLiteralA2B_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent",
+            "Effects"
           ]
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:s12StaticStringV11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -86586,10 +97993,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12StaticStringV11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -86597,18 +98000,20 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV11descriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV11descriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s12StaticStringV16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -86620,10 +98025,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12StaticStringV16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -86631,18 +98032,20 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV16debugDescriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "StringLiteralType",
           "printedName": "StringLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s12StaticStringV0B11LiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -86650,16 +98053,16 @@
               "printedName": "StaticString",
               "usr": "s:s12StaticStringV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s12StaticStringV0B11LiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "ExtendedGraphemeClusterLiteralType",
           "printedName": "ExtendedGraphemeClusterLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s12StaticStringV34ExtendedGraphemeClusterLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -86667,16 +98070,16 @@
               "printedName": "StaticString",
               "usr": "s:s12StaticStringV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s12StaticStringV34ExtendedGraphemeClusterLiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "UnicodeScalarLiteralType",
           "printedName": "UnicodeScalarLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:s12StaticStringV24UnicodeScalarLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -86684,16 +98087,16 @@
               "printedName": "StaticString",
               "usr": "s:s12StaticStringV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s12StaticStringV24UnicodeScalarLiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s12StaticStringV12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -86705,10 +98108,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s12StaticStringV12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -86716,35 +98115,53 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s12StaticStringV12customMirrors0D0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s12StaticStringV12customMirrors0D0Vvp",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s12StaticStringV",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "CustomReflectable",
+        "_ExpressibleByBuiltinExtendedGraphemeClusterLiteral",
+        "_ExpressibleByBuiltinStringLiteral",
+        "ExpressibleByUnicodeScalarLiteral",
+        "ExpressibleByExtendedGraphemeClusterLiteral",
+        "ExpressibleByStringLiteral",
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible",
+        "_ExpressibleByBuiltinUnicodeScalarLiteral"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Strideable",
       "printedName": "Strideable",
-      "declKind": "Protocol",
-      "usr": "s:Sx",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : Comparable, Self.Stride : Comparable, Self.Stride : SignedNumeric>",
-      "conformingProtocols": [
-        "Comparable",
-        "Equatable"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "Stride",
+          "printedName": "Stride",
+          "declKind": "AssociatedType",
+          "usr": "s:Sx6StrideQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(to:)",
-          "declKind": "Func",
-          "usr": "s:Sx8distance2to6StrideQzx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Strideable>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -86756,17 +98173,17 @@
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sx8distance2to6StrideQzx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Strideable>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "advanced",
           "printedName": "advanced(by:)",
-          "declKind": "Func",
-          "usr": "s:Sx8advanced2byx6StrideQz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : Strideable>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -86778,130 +98195,401 @@
               "name": "DependentMember",
               "printedName": "Self.Stride"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sx8advanced2byx6StrideQz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Strideable>",
+          "protocolReq": true
+        },
+        {
+          "kind": "Function",
+          "name": "...",
+          "printedName": "...(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "ClosedRange",
+              "printedName": "ClosedRange<Self>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Self"
+                }
+              ],
+              "usr": "s:SN"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SxsSZ6StrideRpzrlE3zzzoiySNyxGx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Strideable, Self.Stride : SignedInteger>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Stride"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sxss8_PointerRzrlE1poiyxx_6StrideQztFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : _Pointer>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Stride"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sxss8_PointerRzrlE1poiyx6StrideQz_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : _Pointer>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Stride"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sxss8_PointerRzrlE1soiyxx_6StrideQztFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : _Pointer>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-",
+          "printedName": "-(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Stride"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sxss8_PointerRzrlE1soiy6StrideQzx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : _Pointer>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Stride"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sxss8_PointerRzrlE2peoiyyxz_6StrideQztFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : _Pointer>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "-=",
+          "printedName": "-=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "DependentMember",
+              "printedName": "Self.Stride"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sxss8_PointerRzrlE2seoiyyxz_6StrideQztFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : _Pointer>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SxsE1loiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Strideable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SxsE2eeoiySbx_xtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : Strideable>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:Sx",
+      "moduleName": "Swift",
+      "genericSig": "<Self : Comparable, Self.Stride : Comparable, Self.Stride : SignedNumeric>",
+      "conformingProtocols": [
+        "Comparable",
+        "Equatable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "StrideToIterator",
       "printedName": "StrideToIterator",
-      "declKind": "Struct",
-      "usr": "s:s16StrideToIteratorV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element where Element : Strideable>",
-      "conformingProtocols": [
-        "IteratorProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s16StrideToIteratorV4nextxSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s16StrideToIteratorV4nextxSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Strideable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s16StrideToIteratorV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s16StrideToIteratorV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Strideable>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s16StrideToIteratorV",
+      "moduleName": "Swift",
+      "genericSig": "<Element where Element : Strideable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "StrideTo",
       "printedName": "StrideTo",
-      "declKind": "Struct",
-      "usr": "s:s8StrideToV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element where Element : Strideable>",
-      "conformingProtocols": [
-        "Sequence",
-        "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s8StrideToV12makeIterators0abD0VyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "StrideToIterator",
               "printedName": "StrideToIterator<Element>",
-              "usr": "s:s16StrideToIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s16StrideToIteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s8StrideToV12makeIterators0abD0VyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Strideable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s8StrideToV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -86913,11 +98601,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s8StrideToV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Strideable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -86925,85 +98608,91 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s8StrideToV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Strideable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s8StrideToV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s8StrideToV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s8StrideToV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Strideable>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s8StrideToV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "StrideToIterator",
               "printedName": "StrideToIterator<Element>",
-              "usr": "s:s16StrideToIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s16StrideToIteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s8StrideToV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Strideable>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s8StrideToV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s8StrideToV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Strideable>",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s8StrideToV12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -87015,11 +98704,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s8StrideToV12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Strideable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -87027,37 +98711,47 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s8StrideToV12customMirrors0D0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Strideable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s8StrideToV12customMirrors0D0Vvp",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s8StrideToV",
+      "moduleName": "Swift",
+      "genericSig": "<Element where Element : Strideable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "CustomReflectable"
       ]
     },
     {
       "kind": "Function",
       "name": "stride",
       "printedName": "stride(from:to:by:)",
-      "declKind": "Func",
-      "usr": "s:s6stride4from2to2bys8StrideToVyxGx_x0E0QztSxRzlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Strideable>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "StrideTo",
           "printedName": "StrideTo<T>",
-          "usr": "s:s8StrideToV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s8StrideToV"
         },
         {
           "kind": "TypeNominal",
@@ -87074,128 +98768,113 @@
           "name": "DependentMember",
           "printedName": "T.Stride"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s6stride4from2to2bys8StrideToVyxGx_x0E0QztSxRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : Strideable>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "StrideThroughIterator",
       "printedName": "StrideThroughIterator",
-      "declKind": "Struct",
-      "usr": "s:s21StrideThroughIteratorV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element where Element : Strideable>",
-      "conformingProtocols": [
-        "IteratorProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s21StrideThroughIteratorV4nextxSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s21StrideThroughIteratorV4nextxSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Strideable>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s21StrideThroughIteratorV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s21StrideThroughIteratorV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Strideable>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s21StrideThroughIteratorV",
+      "moduleName": "Swift",
+      "genericSig": "<Element where Element : Strideable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "StrideThrough",
       "printedName": "StrideThrough",
-      "declKind": "Struct",
-      "usr": "s:s13StrideThroughV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element where Element : Strideable>",
-      "conformingProtocols": [
-        "Sequence",
-        "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s13StrideThroughV12makeIterators0abD0VyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "StrideThroughIterator",
               "printedName": "StrideThroughIterator<Element>",
-              "usr": "s:s21StrideThroughIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s21StrideThroughIteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13StrideThroughV12makeIterators0abD0VyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Strideable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s13StrideThroughV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -87207,11 +98886,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13StrideThroughV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Strideable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -87219,85 +98893,91 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13StrideThroughV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Strideable>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13StrideThroughV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s13StrideThroughV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s13StrideThroughV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Strideable>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s13StrideThroughV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "StrideThroughIterator",
               "printedName": "StrideThroughIterator<Element>",
-              "usr": "s:s21StrideThroughIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s21StrideThroughIteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s13StrideThroughV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Strideable>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s13StrideThroughV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element where Element : Strideable>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s13StrideThroughV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Element where Element : Strideable>",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s13StrideThroughV12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -87309,11 +98989,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13StrideThroughV12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element where Element : Strideable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -87321,37 +98996,47 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13StrideThroughV12customMirrors0D0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element where Element : Strideable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s13StrideThroughV12customMirrors0D0Vvp",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s13StrideThroughV",
+      "moduleName": "Swift",
+      "genericSig": "<Element where Element : Strideable>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "CustomReflectable"
       ]
     },
     {
       "kind": "Function",
       "name": "stride",
       "printedName": "stride(from:through:by:)",
-      "declKind": "Func",
-      "usr": "s:s6stride4from7through2bys13StrideThroughVyxGx_x0E0QztSxRzlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Strideable>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "StrideThrough",
           "printedName": "StrideThrough<T>",
-          "usr": "s:s13StrideThroughV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s13StrideThroughV"
         },
         {
           "kind": "TypeNominal",
@@ -87368,60 +99053,24 @@
           "name": "DependentMember",
           "printedName": "T.Stride"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s6stride4from7through2bys13StrideThroughVyxGx_x0E0QztSxRzlF",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : Strideable>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "String",
       "printedName": "String",
-      "declKind": "Struct",
-      "usr": "s:SS",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Decodable",
-        "Encodable",
-        "CustomReflectable",
-        "_CustomPlaygroundQuickLookable",
-        "TextOutputStream",
-        "TextOutputStreamable",
-        "Hashable",
-        "_ExpressibleByBuiltinUnicodeScalarLiteral",
-        "_ExpressibleByBuiltinExtendedGraphemeClusterLiteral",
-        "_ExpressibleByBuiltinUTF16StringLiteral",
-        "_ExpressibleByBuiltinStringLiteral",
-        "ExpressibleByStringLiteral",
-        "ExpressibleByExtendedGraphemeClusterLiteral",
-        "ExpressibleByUnicodeScalarLiteral",
-        "CustomDebugStringConvertible",
-        "CustomStringConvertible",
-        "BidirectionalCollection",
-        "Collection",
-        "Sequence",
-        "Equatable",
-        "Comparable",
-        "_SwiftStringView",
-        "_ExpressibleByStringInterpolation",
-        "StringProtocol",
-        "RangeReplaceableCollection",
-        "LosslessStringConvertible",
-        "MirrorPath"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:S2Sycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -87429,19 +99078,18 @@
               "printedName": "String",
               "usr": "s:SS"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:S2Sycfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSSJcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -87455,20 +99103,18 @@
               "printedName": "Character",
               "usr": "s:SJ"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSySSSJcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(from:)",
-          "declKind": "Constructor",
-          "usr": "s:SS4fromSSs7Decoder_p_tKcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -87482,20 +99128,16 @@
               "printedName": "Decoder",
               "usr": "s:s7DecoderP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS4fromSSs7Decoder_p_tKcfc",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(to:)",
-          "declKind": "Func",
-          "usr": "s:SS6encode2toys7Encoder_p_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -87508,16 +99150,16 @@
               "printedName": "Encoder",
               "usr": "s:s7EncoderP"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6encode2toys7Encoder_p_tKF",
+          "moduleName": "Swift",
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(cString:)",
-          "declKind": "Constructor",
-          "usr": "s:SS7cStringSSSPys4Int8VG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -87529,7 +99171,6 @@
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<CChar>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -87544,18 +99185,18 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:SP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS7cStringSSSPys4Int8VG_tcfc",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(cString:)",
-          "declKind": "Constructor",
-          "usr": "s:SS7cStringSSSPys5UInt8VG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -87567,7 +99208,6 @@
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<UInt8>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -87575,24 +99215,23 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS7cStringSSSPys5UInt8VG_tcfc",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(validatingUTF8:)",
-          "declKind": "Constructor",
-          "usr": "s:SS14validatingUTF8SSSgSPys4Int8VG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "String?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -87600,13 +99239,13 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<CChar>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -87621,30 +99260,23 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:SP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS14validatingUTF8SSSgSPys4Int8VG_tcfc",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "decodeCString",
           "printedName": "decodeCString(_:as:repairingInvalidCodeUnits:)",
-          "declKind": "Func",
-          "usr": "s:SS13decodeCString_2as25repairingInvalidCodeUnitsSS6result_Sb11repairsMadetSgSPy0F4UnitQzGSg_xmSbts16_UnicodeEncodingRzlFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Encoding where Encoding : _UnicodeEncoding>",
-          "static": true,
-          "declAttributes": [
-            "Specialize",
-            "Specialize"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "(result: String, repairsMade: Bool)?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -87665,28 +99297,29 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafePointer<Encoding.CodeUnit>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafePointer",
                   "printedName": "UnsafePointer<Encoding.CodeUnit>",
-                  "usr": "s:SP",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "Encoding.CodeUnit"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -87707,22 +99340,21 @@
               "hasDefaultArg": true,
               "usr": "s:Sb"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS13decodeCString_2as25repairingInvalidCodeUnitsSS6result_Sb11repairsMadetSgSPy0F4UnitQzGSg_xmSbts16_UnicodeEncodingRzlFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Encoding where Encoding : _UnicodeEncoding>",
+          "static": true,
+          "declAttributes": [
+            "Specialize",
+            "Specialize"
           ]
         },
         {
           "kind": "Function",
           "name": "withCString",
           "printedName": "withCString(_:)",
-          "declKind": "Func",
-          "usr": "s:SS11withCStringyxxSPys4Int8VGKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Result>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -87733,9 +99365,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafePointer<Int8>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -87746,13 +99375,11 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafePointer<Int8>)",
-                  "usr": "s:SP",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafePointer",
                       "printedName": "UnsafePointer<Int8>",
-                      "usr": "s:SP",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -87760,22 +99387,32 @@
                           "printedName": "Int8",
                           "usr": "s:s4Int8V"
                         }
-                      ]
+                      ],
+                      "usr": "s:SP"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS11withCStringyxxSPys4Int8VGKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Result>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:SS12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -87787,10 +99424,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -87798,23 +99431,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS12customMirrors0B0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SS12customMirrors0B0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:SS25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -87826,10 +99456,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -87837,22 +99463,24 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "write",
           "printedName": "write(_:)",
-          "declKind": "Func",
-          "usr": "s:SS5writeyySSF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -87865,20 +99493,19 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS5writeyySSF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "write",
           "printedName": "write(to:)",
-          "declKind": "Func",
-          "usr": "s:SS5write2toyxz_ts16TextOutputStreamRzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Target where Target : TextOutputStream>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -87890,19 +99517,19 @@
               "name": "GenericTypeParam",
               "printedName": "Target"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS5write2toyxz_ts16TextOutputStreamRzlF",
+          "moduleName": "Swift",
+          "genericSig": "<Target where Target : TextOutputStream>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SS4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -87915,16 +99542,18 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SS9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -87936,10 +99565,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -87947,23 +99572,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SS9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(decoding:as:)",
-          "declKind": "Constructor",
-          "usr": "s:SS8decoding2asSSx_q_mtcSlRzs16_UnicodeEncodingR_8CodeUnitQy_7ElementRtzr0_lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<C, Encoding where C : Collection, Encoding : _UnicodeEncoding, C.Element == Encoding.CodeUnit>",
-          "declAttributes": [
-            "Inline",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -87988,20 +99612,20 @@
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS8decoding2asSSx_q_mtcSlRzs16_UnicodeEncodingR_8CodeUnitQy_7ElementRtzr0_lufc",
+          "moduleName": "Swift",
+          "genericSig": "<C, Encoding where C : Collection, Encoding : _UnicodeEncoding, C.Element == Encoding.CodeUnit>",
+          "declAttributes": [
+            "Inline",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(decodingCString:as:)",
-          "declKind": "Constructor",
-          "usr": "s:SS15decodingCString2asSSSPy8CodeUnitQzG_xmtcs16_UnicodeEncodingRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Encoding where Encoding : _UnicodeEncoding>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -88013,14 +99637,14 @@
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<Encoding.CodeUnit>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Encoding.CodeUnit"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             },
             {
               "kind": "TypeNominal",
@@ -88034,22 +99658,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS15decodingCString2asSSSPy8CodeUnitQzG_xmtcs16_UnicodeEncodingRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<Encoding where Encoding : _UnicodeEncoding>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "withCString",
           "printedName": "withCString(encodedAs:_:)",
-          "declKind": "Func",
-          "usr": "s:SS11withCString9encodedAs_xq_m_xSPy8CodeUnitQy_GKXEtKs16_UnicodeEncodingR_r0_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Result, TargetEncoding where TargetEncoding : _UnicodeEncoding>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -88072,9 +99693,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafePointer<TargetEncoding.CodeUnit>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -88085,38 +99703,43 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafePointer<TargetEncoding.CodeUnit>)",
-                  "usr": "s:SP",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafePointer",
                       "printedName": "UnsafePointer<TargetEncoding.CodeUnit>",
-                      "usr": "s:SP",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "DependentMember",
                           "printedName": "TargetEncoding.CodeUnit"
                         }
-                      ]
+                      ],
+                      "usr": "s:SP"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS11withCString9encodedAs_xq_m_xSPy8CodeUnitQy_GKXEtKs16_UnicodeEncodingR_r0_lF",
+          "moduleName": "Swift",
+          "genericSig": "<Result, TargetEncoding where TargetEncoding : _UnicodeEncoding>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSs7UnicodeO6ScalarVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -88130,19 +99753,18 @@
               "printedName": "Unicode.Scalar",
               "usr": "s:s7UnicodeO6ScalarV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSySSs7UnicodeO6ScalarVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(stringLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:SS13stringLiteralS2S_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -88156,16 +99778,18 @@
               "printedName": "String",
               "usr": "s:SS"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS13stringLiteralS2S_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "StringLiteralType",
           "printedName": "StringLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:SS17StringLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -88173,16 +99797,16 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SS17StringLiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "ExtendedGraphemeClusterLiteralType",
           "printedName": "ExtendedGraphemeClusterLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:SS34ExtendedGraphemeClusterLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -88190,16 +99814,16 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SS34ExtendedGraphemeClusterLiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "UnicodeScalarLiteralType",
           "printedName": "UnicodeScalarLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:SS24UnicodeScalarLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -88207,16 +99831,16 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SS24UnicodeScalarLiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:SS16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -88228,10 +99852,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -88239,19 +99859,20 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS16debugDescriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SS16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(_:)",
-          "declKind": "Func",
-          "usr": "s:SS6appendyySSF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -88264,16 +99885,81 @@
               "printedName": "String",
               "usr": "s:SS"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6appendyySSF",
+          "moduleName": "Swift",
+          "mutating": true
+        },
+        {
+          "kind": "Function",
+          "name": "+",
+          "printedName": "+(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS1poiyS2S_SStFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Semantics",
+            "Effects",
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "+=",
+          "printedName": "+=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Void",
+              "printedName": "()"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS2peoiyySSz_SStFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "lowercased",
           "printedName": "lowercased()",
-          "declKind": "Func",
-          "usr": "s:SS10lowercasedSSyF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -88281,16 +99967,15 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS10lowercasedSSyF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "uppercased",
           "printedName": "uppercased()",
-          "declKind": "Func",
-          "usr": "s:SS10uppercasedSSyF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -88298,20 +99983,15 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS10uppercasedSSyF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSxcs25LosslessStringConvertibleRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T where T : LosslessStringConvertible>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -88324,19 +100004,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSySSxcs25LosslessStringConvertibleRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<T where T : LosslessStringConvertible>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:SS11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -88348,10 +100028,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -88359,18 +100035,23 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS11descriptionSSvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "IndexDistance",
           "printedName": "IndexDistance",
-          "declKind": "TypeAlias",
-          "usr": "s:SS13IndexDistancea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -88378,16 +100059,15 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SS13IndexDistancea",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:SS11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -88395,19 +100075,15 @@
               "printedName": "Substring",
               "usr": "s:Ss"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SS11SubSequencea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:SS10startIndexSS0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -88419,10 +100095,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS10startIndexSS0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -88430,21 +100102,23 @@
                   "printedName": "String.Index",
                   "usr": "s:SS5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS10startIndexSS0B0Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS10startIndexSS0B0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:SS8endIndexSS0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -88456,10 +100130,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS8endIndexSS0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -88467,18 +100137,23 @@
                   "printedName": "String.Index",
                   "usr": "s:SS5IndexV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS8endIndexSS0B0Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS8endIndexSS0B0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:SS5countSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -88490,10 +100165,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS5countSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -88501,18 +100172,20 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS5countSivg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SS5countSivp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:SS5index5afterSS5IndexVAD_tF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -88526,16 +100199,15 @@
               "printedName": "String.Index",
               "usr": "s:SS5IndexV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS5index5afterSS5IndexVAD_tF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:SS5index6beforeSS5IndexVAD_tF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -88549,16 +100221,15 @@
               "printedName": "String.Index",
               "usr": "s:SS5IndexV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS5index6beforeSS5IndexVAD_tF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SS5index_8offsetBySS5IndexVAD_SitF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -88585,22 +100256,20 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS5index_8offsetBySS5IndexVAD_SitF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SS5index_8offsetBy07limitedC0SS5IndexVSgAE_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "String.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -88608,7 +100277,8 @@
                   "printedName": "String.Index",
                   "usr": "s:SS5IndexV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -88635,16 +100305,15 @@
               "printedName": "String.Index",
               "usr": "s:SS5IndexV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS5index_8offsetBy07limitedC0SS5IndexVSgAE_SiAEtF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SS8distance4from2toSiSS5IndexV_AEtF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -88671,16 +100340,37 @@
               "printedName": "String.Index",
               "usr": "s:SS5IndexV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS8distance4from2toSiSS5IndexV_AEtF",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Index",
+              "printedName": "String.Index",
+              "usr": "s:SS5IndexV"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SSySJSS5IndexVcip",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:SS7Elementa",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -88688,22 +100378,21 @@
               "printedName": "Character",
               "usr": "s:SJ"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SS7Elementa",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:SS8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "IndexingIterator",
               "printedName": "IndexingIterator<String>",
-              "usr": "s:s16IndexingIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -88711,24 +100400,24 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:s16IndexingIteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SS8Iteratora",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:SS7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DefaultIndices",
               "printedName": "DefaultIndices<String>",
-              "usr": "s:SI",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -88736,38 +100425,152 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:SI"
             }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SS7Indicesa",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS2eeoiySbSS_SStFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS1loiySbSS_SStFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "Struct",
-          "usr": "s:SS5IndexV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "Equatable",
-            "Comparable",
-            "Hashable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS5IndexV2eeoiySbAB_ABtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS5IndexV1loiySbAB_ABtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:SS5IndexV4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -88780,16 +100583,18 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS5IndexV4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:SS5IndexV9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -88801,10 +100606,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS5IndexV9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -88812,22 +100613,22 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS5IndexV9hashValueSivg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:SS5IndexV9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(encodedOffset:transcodedOffset:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV13encodedOffset010transcodedC0ABSi_Sitcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable",
-                "Inline"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -88847,20 +100648,20 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV13encodedOffset010transcodedC0ABSi_Sitcfc",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "Inlinable",
+                "Inline"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(from:adjustingEncodedOffsetBy:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV4from24adjustingEncodedOffsetByA2B_Sitcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable",
-                "Inline"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -88880,19 +100681,20 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV4from24adjustingEncodedOffsetByA2B_Sitcfc",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "Inlinable",
+                "Inline"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(encodedOffset:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV13encodedOffsetABSi_tcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -88906,19 +100708,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV13encodedOffsetABSi_tcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(encodedOffset:transcodedOffset:buffer:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV13encodedOffset010transcodedC06bufferABSi_Sis16_ValidUTF8BufferVys6UInt32VGtcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -88947,7 +100748,6 @@
                       "kind": "TypeNominal",
                       "name": "_ValidUTF8Buffer",
                       "printedName": "_ValidUTF8Buffer<UInt32>",
-                      "usr": "s:s16_ValidUTF8BufferV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -88955,23 +100755,24 @@
                           "printedName": "UInt32",
                           "usr": "s:s6UInt32V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s16_ValidUTF8BufferV"
                     }
                   ]
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV13encodedOffset010transcodedC06bufferABSi_Sis16_ValidUTF8BufferVys6UInt32VGtcfc",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(encodedOffset:characterStride:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV13encodedOffset15characterStrideABSi_Sitcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -88991,19 +100792,19 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV13encodedOffset15characterStrideABSi_Sitcfc",
+              "moduleName": "Swift",
+              "isInternal": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "encodedOffset",
               "printedName": "encodedOffset",
-              "declKind": "Var",
-              "usr": "s:SS5IndexV13encodedOffsetSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -89015,10 +100816,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS5IndexV13encodedOffsetSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -89026,24 +100823,28 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS5IndexV13encodedOffsetSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS5IndexV13encodedOffsetSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:within:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV_6withinABSgAB_SStcfc",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "String.Index?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -89051,7 +100852,8 @@
                       "printedName": "String.Index",
                       "usr": "s:SS5IndexV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -89065,25 +100867,20 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV_6withinABSgAB_SStcfc",
+              "moduleName": "Swift"
             },
             {
               "kind": "Function",
               "name": "samePosition",
               "printedName": "samePosition(in:)",
-              "declKind": "Func",
-              "usr": "s:SS5IndexV12samePosition2inABSgSS8UTF8ViewV_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "String.UTF8View.Index?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -89098,7 +100895,8 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -89106,25 +100904,23 @@
                   "printedName": "String.UTF8View",
                   "usr": "s:SS8UTF8ViewV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS5IndexV12samePosition2inABSgSS8UTF8ViewV_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "samePosition",
               "printedName": "samePosition(in:)",
-              "declKind": "Func",
-              "usr": "s:SS5IndexV12samePosition2inABSgSS9UTF16ViewV_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "String.UTF16View.Index?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -89139,7 +100935,8 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -89147,25 +100944,23 @@
                   "printedName": "String.UTF16View",
                   "usr": "s:SS9UTF16ViewV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS5IndexV12samePosition2inABSgSS9UTF16ViewV_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:within:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV_6withinABSgAB_SS17UnicodeScalarViewVtcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "String.Index?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -89173,7 +100968,8 @@
                       "printedName": "String.Index",
                       "usr": "s:SS5IndexV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNameAlias",
@@ -89194,25 +100990,23 @@
                   "printedName": "String.UnicodeScalarView",
                   "usr": "s:SS17UnicodeScalarViewV"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV_6withinABSgAB_SS17UnicodeScalarViewVtcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "samePosition",
               "printedName": "samePosition(in:)",
-              "declKind": "Func",
-              "usr": "s:SS5IndexV12samePosition2inABSgSS_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "String.Index?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -89220,7 +101014,8 @@
                       "printedName": "String.Index",
                       "usr": "s:SS5IndexV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -89228,25 +101023,23 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS5IndexV12samePosition2inABSgSS_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:within:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV_6withinABSgAB_SS9UTF16ViewVtcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "String.Index?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -89254,7 +101047,8 @@
                       "printedName": "String.Index",
                       "usr": "s:SS5IndexV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -89268,25 +101062,23 @@
                   "printedName": "String.UTF16View",
                   "usr": "s:SS9UTF16ViewV"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV_6withinABSgAB_SS9UTF16ViewVtcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "samePosition",
               "printedName": "samePosition(in:)",
-              "declKind": "Func",
-              "usr": "s:SS5IndexV12samePosition2inABSgSS17UnicodeScalarViewV_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "String.UnicodeScalarIndex?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -89301,7 +101093,8 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -89309,25 +101102,23 @@
                   "printedName": "String.UnicodeScalarView",
                   "usr": "s:SS17UnicodeScalarViewV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS5IndexV12samePosition2inABSgSS17UnicodeScalarViewV_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:within:)",
-              "declKind": "Constructor",
-              "usr": "s:SS5IndexV_6withinABSgAB_SS8UTF8ViewVtcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "String.Index?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -89335,7 +101126,8 @@
                       "printedName": "String.Index",
                       "usr": "s:SS5IndexV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -89349,22 +101141,31 @@
                   "printedName": "String.UTF8View",
                   "usr": "s:SS8UTF8ViewV"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS5IndexV_6withinABSgAB_SS8UTF8ViewVtcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SS5IndexV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "Equatable",
+            "Comparable",
+            "Hashable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(stringInterpolation:)",
-          "declKind": "Constructor",
-          "usr": "s:SS19stringInterpolationS2Sd_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Effects",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -89376,7 +101177,6 @@
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[String]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -89384,22 +101184,47 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS19stringInterpolationS2Sd_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Effects",
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(stringInterpolationSegment:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "T"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SS26stringInterpolationSegmentSSx_tclufc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<T>",
           "declAttributes": [
             "Inlinable"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(stringInterpolationSegment:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -89412,20 +101237,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(stringInterpolationSegment:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:SS26stringInterpolationSegmentSSx_tcs20TextOutputStreamableRzlufc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<T where T : TextOutputStreamable>",
           "declAttributes": [
             "Inlinable"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(stringInterpolationSegment:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -89438,46 +101262,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(stringInterpolationSegment:)",
+          ],
           "declKind": "Constructor",
           "usr": "s:SS26stringInterpolationSegmentSSx_tcs23CustomStringConvertibleRzlufc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<T where T : CustomStringConvertible>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "T"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(stringInterpolationSegment:)",
-          "declKind": "Constructor",
-          "usr": "s:SS26stringInterpolationSegmentSSx_tcs23CustomStringConvertibleRzs20TextOutputStreamableRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T where T : CustomStringConvertible, T : TextOutputStreamable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -89490,19 +101287,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS26stringInterpolationSegmentSSx_tcs23CustomStringConvertibleRzs20TextOutputStreamableRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<T where T : CustomStringConvertible, T : TextOutputStreamable>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(repeating:count:)",
-          "declKind": "Constructor",
-          "usr": "s:SS9repeating5countS2S_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -89522,19 +101319,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS9repeating5countS2S_Sitcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "isEmpty",
           "printedName": "isEmpty",
-          "declKind": "Var",
-          "usr": "s:SS7isEmptySbvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -89546,10 +101342,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS7isEmptySbvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -89557,18 +101349,23 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS7isEmptySbvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS7isEmptySbvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hasPrefix",
           "printedName": "hasPrefix(_:)",
-          "declKind": "Func",
-          "usr": "s:SS9hasPrefixySbSSF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -89582,16 +101379,15 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS9hasPrefixySbSSF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "hasSuffix",
           "printedName": "hasSuffix(_:)",
-          "declKind": "Func",
-          "usr": "s:SS9hasSuffixySbSSF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -89605,20 +101401,15 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS9hasSuffixySbSSF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:radix:uppercase:)",
-          "declKind": "Constructor",
-          "usr": "s:SS_5radix9uppercaseSSx_SiSbtcSzRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T where T : BinaryInteger>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -89645,19 +101436,19 @@
               "hasDefaultArg": true,
               "usr": "s:Sb"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS_5radix9uppercaseSSx_SiSbtcSzRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<T where T : BinaryInteger>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(repeating:count:)",
-          "declKind": "Constructor",
-          "usr": "s:SS9repeating5countSSSJ_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -89677,46 +101468,43 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS9repeating5countSSSJ_Sitcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "S"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:SSySSxcs25LosslessStringConvertibleRzSTRzSJ7ElementSTRtzlufc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<S where S : LosslessStringConvertible, S : Sequence, S.Element == Character>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "S"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSxcSTRzSJ7ElementRtzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : Sequence, S.Element == Character>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -89729,17 +101517,19 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSySSxcSTRzSJ7ElementRtzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<S where S : Sequence, S.Element == Character>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "reserveCapacity",
           "printedName": "reserveCapacity(_:)",
-          "declKind": "Func",
-          "usr": "s:SS15reserveCapacityyySiF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -89752,17 +101542,16 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS15reserveCapacityyySiF",
+          "moduleName": "Swift",
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(_:)",
-          "declKind": "Func",
-          "usr": "s:SS6appendyySJF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -89775,17 +101564,16 @@
               "printedName": "Character",
               "usr": "s:SJ"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6appendyySJF",
+          "moduleName": "Swift",
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:SS6append10contentsOfySS_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -89798,17 +101586,16 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6append10contentsOfySS_tF",
+          "moduleName": "Swift",
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:SS6append10contentsOfySs_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -89821,21 +101608,16 @@
               "printedName": "Substring",
               "usr": "s:Ss"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6append10contentsOfySs_tF",
+          "moduleName": "Swift",
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:SS6append10contentsOfyx_tSTRzSJ7ElementRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : Sequence, S.Element == Character>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -89847,21 +101629,20 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6append10contentsOfyx_tSTRzSJ7ElementRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<S where S : Sequence, S.Element == Character>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "replaceSubrange",
           "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:SS15replaceSubrange_4withySnySS5IndexVG_xtSlRzSJ7ElementRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<C where C : Collection, C.Element == Character>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -89872,7 +101653,6 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<String.Index>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -89880,27 +101660,28 @@
                   "printedName": "String.Index",
                   "usr": "s:SS5IndexV"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "C"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS15replaceSubrange_4withySnySS5IndexVG_xtSlRzSJ7ElementRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<C where C : Collection, C.Element == Character>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(_:at:)",
-          "declKind": "Func",
-          "usr": "s:SS6insert_2atySJ_SS5IndexVtF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -89919,21 +101700,19 @@
               "printedName": "String.Index",
               "usr": "s:SS5IndexV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6insert_2atySJ_SS5IndexVtF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "insert",
           "printedName": "insert(contentsOf:at:)",
-          "declKind": "Func",
-          "usr": "s:SS6insert10contentsOf2atyx_SS5IndexVtSlRzSJ7ElementRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : Collection, S.Element == Character>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -89951,21 +101730,20 @@
               "printedName": "String.Index",
               "usr": "s:SS5IndexV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6insert10contentsOf2atyx_SS5IndexVtSlRzSJ7ElementRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<S where S : Collection, S.Element == Character>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "remove",
           "printedName": "remove(at:)",
-          "declKind": "Func",
-          "usr": "s:SS6remove2atSJSS5IndexV_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -89979,20 +101757,20 @@
               "printedName": "String.Index",
               "usr": "s:SS5IndexV"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS6remove2atSJSS5IndexV_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeSubrange",
           "printedName": "removeSubrange(_:)",
-          "declKind": "Func",
-          "usr": "s:SS14removeSubrangeyySnySS5IndexVGF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -90003,7 +101781,6 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<String.Index>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -90011,22 +101788,22 @@
                   "printedName": "String.Index",
                   "usr": "s:SS5IndexV"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS14removeSubrangeyySnySS5IndexVGF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "removeAll",
           "printedName": "removeAll(keepingCapacity:)",
-          "declKind": "Func",
-          "usr": "s:SS9removeAll15keepingCapacityySb_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -90040,20 +101817,19 @@
               "hasDefaultArg": true,
               "usr": "s:Sb"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SS9removeAll15keepingCapacityySb_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "max",
           "printedName": "max(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SS3maxyxx_xtSLRzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T where T : Comparable>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -90070,20 +101846,19 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS3maxyxx_xtSLRzlF",
+          "moduleName": "Swift",
+          "genericSig": "<T where T : Comparable>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "min",
           "printedName": "min(_:_:)",
-          "declKind": "Func",
-          "usr": "s:SS3minyxx_xtSLRzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T where T : Comparable>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -90100,39 +101875,24 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SS3minyxx_xtSLRzlF",
+          "moduleName": "Swift",
+          "genericSig": "<T where T : Comparable>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "UnicodeScalarView",
           "printedName": "UnicodeScalarView",
-          "declKind": "Struct",
-          "usr": "s:SS17UnicodeScalarViewV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "CustomStringConvertible",
-            "CustomDebugStringConvertible",
-            "Collection",
-            "Sequence",
-            "_SwiftStringView",
-            "RangeReplaceableCollection",
-            "CustomReflectable",
-            "_CustomPlaygroundQuickLookable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Index",
               "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:SS17UnicodeScalarViewV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -90140,19 +101900,15 @@
                   "printedName": "String.Index",
                   "usr": "s:SS5IndexV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SS17UnicodeScalarViewV5Indexa",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:SS17UnicodeScalarViewV10startIndexSS0E0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -90171,10 +101927,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS17UnicodeScalarViewV10startIndexSS0E0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -90189,21 +101941,23 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS17UnicodeScalarViewV10startIndexSS0E0Vvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS17UnicodeScalarViewV10startIndexSS0E0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:SS17UnicodeScalarViewV8endIndexSS0E0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -90222,10 +101976,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS17UnicodeScalarViewV8endIndexSS0E0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -90240,21 +101990,23 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS17UnicodeScalarViewV8endIndexSS0E0Vvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS17UnicodeScalarViewV8endIndexSS0E0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV5index5afterSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -90282,19 +102034,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS17UnicodeScalarViewV5index5afterSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV5index6beforeSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -90322,34 +102073,55 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS17UnicodeScalarViewV5index6beforeSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Scalar",
+                  "printedName": "Unicode.Scalar",
+                  "usr": "s:s7UnicodeO6ScalarV"
+                },
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "String.UnicodeScalarView.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ]
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SS17UnicodeScalarViewVys0A0O0B0VSS5IndexVcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "Struct",
-              "usr": "s:SS17UnicodeScalarViewV8IteratorV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "IteratorProtocol"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
               "children": [
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init(_:)",
-                  "declKind": "Constructor",
-                  "usr": "s:SS17UnicodeScalarViewV8IteratorVyADs11_StringGutsVcfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -90363,26 +102135,24 @@
                       "printedName": "_StringGuts",
                       "usr": "s:s11_StringGutsV"
                     }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:SS17UnicodeScalarViewV8IteratorVyADs11_StringGutsVcfc",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
                   "kind": "Function",
                   "name": "next",
                   "printedName": "next()",
-                  "declKind": "Func",
-                  "usr": "s:SS17UnicodeScalarViewV8IteratorV4nexts0A0O0B0VSgyF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "mutating": true,
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
                       "printedName": "Unicode.Scalar?",
-                      "usr": "s:Sq",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -90390,18 +102160,22 @@
                           "printedName": "Unicode.Scalar",
                           "usr": "s:s7UnicodeO6ScalarV"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     }
-                  ]
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS17UnicodeScalarViewV8IteratorV4nexts0A0O0B0VSgyF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ],
+                  "mutating": true
                 },
                 {
                   "kind": "TypeAlias",
                   "name": "Element",
                   "printedName": "Element",
-                  "declKind": "TypeAlias",
-                  "usr": "s:SS17UnicodeScalarViewV8IteratorV7Elementa",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -90409,21 +102183,27 @@
                       "printedName": "Unicode.Scalar",
                       "usr": "s:s7UnicodeO6ScalarV"
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:SS17UnicodeScalarViewV8IteratorV7Elementa",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
+              ],
+              "declKind": "Struct",
+              "usr": "s:SS17UnicodeScalarViewV8IteratorV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "IteratorProtocol"
               ]
             },
             {
               "kind": "Function",
               "name": "makeIterator",
               "printedName": "makeIterator()",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV12makeIteratorAB0E0VyF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -90431,19 +102211,18 @@
                   "printedName": "String.UnicodeScalarView.Iterator",
                   "usr": "s:SS17UnicodeScalarViewV8IteratorV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS17UnicodeScalarViewV12makeIteratorAB0E0VyF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "description",
               "printedName": "description",
-              "declKind": "Var",
-              "usr": "s:SS17UnicodeScalarViewV11descriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -90455,10 +102234,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS17UnicodeScalarViewV11descriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -90466,18 +102241,23 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS17UnicodeScalarViewV11descriptionSSvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS17UnicodeScalarViewV11descriptionSSvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "debugDescription",
               "printedName": "debugDescription",
-              "declKind": "Var",
-              "usr": "s:SS17UnicodeScalarViewV16debugDescriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -90489,10 +102269,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS17UnicodeScalarViewV16debugDescriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -90500,18 +102276,20 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS17UnicodeScalarViewV16debugDescriptionSSvg",
+                  "moduleName": "Swift"
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:SS17UnicodeScalarViewV16debugDescriptionSSvp",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:SS17UnicodeScalarViewV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -90519,22 +102297,21 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SS17UnicodeScalarViewV7Elementa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Indices",
               "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:SS17UnicodeScalarViewV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DefaultIndices",
                   "printedName": "DefaultIndices<String.UnicodeScalarView>",
-                  "usr": "s:SI",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -90542,21 +102319,19 @@
                       "printedName": "String.UnicodeScalarView",
                       "usr": "s:SS17UnicodeScalarViewV"
                     }
-                  ]
+                  ],
+                  "usr": "s:SI"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SS17UnicodeScalarViewV7Indicesa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init()",
-              "declKind": "Constructor",
-              "usr": "s:SS17UnicodeScalarViewVABycfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -90564,17 +102339,18 @@
                   "printedName": "String.UnicodeScalarView",
                   "usr": "s:SS17UnicodeScalarViewV"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:SS17UnicodeScalarViewVABycfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "reserveCapacity",
               "printedName": "reserveCapacity(_:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV15reserveCapacityyySiF",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -90587,17 +102363,16 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:SS17UnicodeScalarViewV15reserveCapacityyySiF",
+              "moduleName": "Swift",
+              "mutating": true
             },
             {
               "kind": "Function",
               "name": "append",
               "printedName": "append(_:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV6appendyys0A0O0B0VF",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -90610,18 +102385,16 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:SS17UnicodeScalarViewV6appendyys0A0O0B0VF",
+              "moduleName": "Swift",
+              "mutating": true
             },
             {
               "kind": "Function",
               "name": "append",
               "printedName": "append(contentsOf:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV6append10contentsOfyx_tSTRzs0A0O0B0V7ElementRtzlF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<S where S : Sequence, S.Element == Unicode.Scalar>",
-              "mutating": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -90633,18 +102406,17 @@
                   "name": "GenericTypeParam",
                   "printedName": "S"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:SS17UnicodeScalarViewV6append10contentsOfyx_tSTRzs0A0O0B0V7ElementRtzlF",
+              "moduleName": "Swift",
+              "genericSig": "<S where S : Sequence, S.Element == Unicode.Scalar>",
+              "mutating": true
             },
             {
               "kind": "Function",
               "name": "replaceSubrange",
               "printedName": "replaceSubrange(_:with:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV15replaceSubrange_4withySnySS5IndexVG_xtSlRzs0A0O0B0V7ElementRtzlF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<C where C : Collection, C.Element == Unicode.Scalar>",
-              "mutating": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -90655,7 +102427,6 @@
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<String.UnicodeScalarView.Index>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -90670,23 +102441,25 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "C"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:SS17UnicodeScalarViewV15replaceSubrange_4withySnySS5IndexVG_xtSlRzs0A0O0B0V7ElementRtzlF",
+              "moduleName": "Swift",
+              "genericSig": "<C where C : Collection, C.Element == Unicode.Scalar>",
+              "mutating": true
             },
             {
               "kind": "Var",
               "name": "customMirror",
               "printedName": "customMirror",
-              "declKind": "Var",
-              "usr": "s:SS17UnicodeScalarViewV12customMirrors0E0Vvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -90698,10 +102471,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS17UnicodeScalarViewV12customMirrors0E0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -90709,18 +102478,20 @@
                       "printedName": "Mirror",
                       "usr": "s:s6MirrorV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS17UnicodeScalarViewV12customMirrors0E0Vvg",
+                  "moduleName": "Swift"
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:SS17UnicodeScalarViewV12customMirrors0E0Vvp",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:SS17UnicodeScalarViewV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -90728,20 +102499,63 @@
                   "printedName": "Substring.UnicodeScalarView",
                   "usr": "s:Ss17UnicodeScalarViewV"
                 }
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SS17UnicodeScalarViewV11SubSequencea",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "SubSequence",
+                  "printedName": "String.UnicodeScalarView.SubSequence",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnicodeScalarView",
+                      "printedName": "Substring.UnicodeScalarView",
+                      "usr": "s:Ss17UnicodeScalarViewV"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<String.UnicodeScalarView.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Index",
+                      "printedName": "String.UnicodeScalarView.Index",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
+                      ]
+                    }
+                  ],
+                  "usr": "s:Sn"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SS17UnicodeScalarViewVySsAAVSnySS5IndexVGcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Available",
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "customPlaygroundQuickLook",
               "printedName": "customPlaygroundQuickLook",
-              "declKind": "Var",
-              "usr": "s:SS17UnicodeScalarViewV25customPlaygroundQuickLooks01_efG0Ovp",
-              "location": "",
-              "moduleName": "Swift",
-              "deprecated": true,
-              "declAttributes": [
-                "Available"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -90753,10 +102567,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS17UnicodeScalarViewV25customPlaygroundQuickLooks01_efG0Ovg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -90764,224 +102574,43 @@
                       "printedName": "_PlaygroundQuickLook",
                       "usr": "s:s20_PlaygroundQuickLookO"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS17UnicodeScalarViewV25customPlaygroundQuickLooks01_efG0Ovg",
+                  "moduleName": "Swift"
                 }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV5index5afterSS5IndexVAFSg_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Available"
               ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UnicodeScalarView.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UnicodeScalarView.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(_:offsetBy:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV5index_8offsetBySS5IndexVAFSg_SitF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UnicodeScalarView.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UnicodeScalarView.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UnicodeScalarView.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "distance",
-              "printedName": "distance(from:to:)",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV8distance4from2toSiSS5IndexVSg_AHtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UnicodeScalarView.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UnicodeScalarView.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UnicodeScalarView.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UnicodeScalarView.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "popFirst",
-              "printedName": "popFirst()",
-              "declKind": "Func",
-              "usr": "s:SS17UnicodeScalarViewV8popFirsts0A0O0B0VSgyF",
-              "location": "",
+              "declKind": "Var",
+              "usr": "s:SS17UnicodeScalarViewV25customPlaygroundQuickLooks01_efG0Ovp",
               "moduleName": "Swift",
               "deprecated": true,
-              "mutating": true,
               "declAttributes": [
                 "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UnicodeScalarView.Element?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Element",
-                      "printedName": "String.UnicodeScalarView.Element",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Scalar",
-                          "printedName": "Unicode.Scalar",
-                          "usr": "s:s7UnicodeO6ScalarV"
-                        }
-                      ]
-                    }
-                  ]
-                }
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SS17UnicodeScalarViewV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "BidirectionalCollection",
+            "CustomStringConvertible",
+            "CustomDebugStringConvertible",
+            "Collection",
+            "Sequence",
+            "_SwiftStringView",
+            "RangeReplaceableCollection",
+            "CustomReflectable",
+            "_CustomPlaygroundQuickLookable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSyS2S17UnicodeScalarViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -90995,16 +102624,18 @@
               "printedName": "String.UnicodeScalarView",
               "usr": "s:SS17UnicodeScalarViewV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSyS2S17UnicodeScalarViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "UnicodeScalarIndex",
           "printedName": "UnicodeScalarIndex",
-          "declKind": "TypeAlias",
-          "usr": "s:SS18UnicodeScalarIndexa",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -91019,19 +102650,15 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SS18UnicodeScalarIndexa",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "unicodeScalars",
           "printedName": "unicodeScalars",
-          "declKind": "Var",
-          "usr": "s:SS14unicodeScalarsSS17UnicodeScalarViewVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -91043,10 +102670,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS14unicodeScalarsSS17UnicodeScalarViewVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -91054,17 +102677,15 @@
                   "printedName": "String.UnicodeScalarView",
                   "usr": "s:SS17UnicodeScalarViewV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS14unicodeScalarsSS17UnicodeScalarViewVvg",
+              "moduleName": "Swift"
             },
             {
               "kind": "Setter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS14unicodeScalarsSS17UnicodeScalarViewVvs",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -91077,40 +102698,29 @@
                   "printedName": "String.UnicodeScalarView",
                   "usr": "s:SS17UnicodeScalarViewV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS14unicodeScalarsSS17UnicodeScalarViewVvs",
+              "moduleName": "Swift",
+              "mutating": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS14unicodeScalarsSS17UnicodeScalarViewVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "UTF16View",
           "printedName": "UTF16View",
-          "declKind": "Struct",
-          "usr": "s:SS9UTF16ViewV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "CustomStringConvertible",
-            "CustomDebugStringConvertible",
-            "Collection",
-            "Sequence",
-            "_SwiftStringView",
-            "CustomReflectable",
-            "_CustomPlaygroundQuickLookable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Index",
               "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:SS9UTF16ViewV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -91118,19 +102728,15 @@
                   "printedName": "String.Index",
                   "usr": "s:SS5IndexV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SS9UTF16ViewV5Indexa",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:SS9UTF16ViewV10startIndexSS0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -91149,10 +102755,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS9UTF16ViewV10startIndexSS0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -91167,21 +102769,23 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS9UTF16ViewV10startIndexSS0D0Vvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS9UTF16ViewV10startIndexSS0D0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:SS9UTF16ViewV8endIndexSS0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -91200,10 +102804,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS9UTF16ViewV8endIndexSS0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -91218,35 +102818,28 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS9UTF16ViewV8endIndexSS0D0Vvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS9UTF16ViewV8endIndexSS0D0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "Indices",
               "printedName": "Indices",
-              "declKind": "Struct",
-              "usr": "s:SS9UTF16ViewV7IndicesV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "BidirectionalCollection",
-                "Collection",
-                "Sequence"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
               "children": [
                 {
                   "kind": "TypeAlias",
                   "name": "Index",
                   "printedName": "Index",
-                  "declKind": "TypeAlias",
-                  "usr": "s:SS9UTF16ViewV7IndicesV5Indexa",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -91261,16 +102854,15 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:SS9UTF16ViewV7IndicesV5Indexa",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "TypeAlias",
                   "name": "Indices",
                   "printedName": "Indices",
-                  "declKind": "TypeAlias",
-                  "usr": "s:SS9UTF16ViewV7IndicesVACa",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -91278,16 +102870,15 @@
                       "printedName": "String.UTF16View.Indices",
                       "usr": "s:SS9UTF16ViewV7IndicesV"
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:SS9UTF16ViewV7IndicesVACa",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "TypeAlias",
                   "name": "SubSequence",
                   "printedName": "SubSequence",
-                  "declKind": "TypeAlias",
-                  "usr": "s:SS9UTF16ViewV7IndicesV11SubSequencea",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -91295,19 +102886,15 @@
                       "printedName": "String.UTF16View.Indices",
                       "usr": "s:SS9UTF16ViewV7IndicesV"
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:SS9UTF16ViewV7IndicesV11SubSequencea",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "startIndex",
                   "printedName": "startIndex",
-                  "declKind": "Var",
-                  "usr": "s:SS9UTF16ViewV7IndicesV10startIndexSS0E0Vvp",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -91326,10 +102913,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:SS9UTF16ViewV7IndicesV10startIndexSS0E0Vvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNameAlias",
@@ -91344,21 +102927,23 @@
                             }
                           ]
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS9UTF16ViewV7IndicesV10startIndexSS0E0Vvg",
+                      "moduleName": "Swift"
                     }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS9UTF16ViewV7IndicesV10startIndexSS0E0Vvp",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
                   "kind": "Var",
                   "name": "endIndex",
                   "printedName": "endIndex",
-                  "declKind": "Var",
-                  "usr": "s:SS9UTF16ViewV7IndicesV8endIndexSS0E0Vvp",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -91377,10 +102962,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:SS9UTF16ViewV7IndicesV8endIndexSS0E0Vvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNameAlias",
@@ -91395,21 +102976,23 @@
                             }
                           ]
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS9UTF16ViewV7IndicesV8endIndexSS0E0Vvg",
+                      "moduleName": "Swift"
                     }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS9UTF16ViewV7IndicesV8endIndexSS0E0Vvp",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
                   "kind": "Var",
                   "name": "indices",
                   "printedName": "indices",
-                  "declKind": "Var",
-                  "usr": "s:SS9UTF16ViewV7IndicesV7indicesADvp",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -91428,10 +103011,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:SS9UTF16ViewV7IndicesV7indicesADvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNameAlias",
@@ -91446,21 +103025,23 @@
                             }
                           ]
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:SS9UTF16ViewV7IndicesV7indicesADvg",
+                      "moduleName": "Swift"
                     }
-                  ]
-                },
-                {
-                  "kind": "Function",
-                  "name": "index",
-                  "printedName": "index(after:)",
-                  "declKind": "Func",
-                  "usr": "s:SS9UTF16ViewV7IndicesV5index5afterSS5IndexVAH_tF",
-                  "location": "",
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:SS9UTF16ViewV7IndicesV7indicesADvp",
                   "moduleName": "Swift",
                   "declAttributes": [
                     "Inlinable"
-                  ],
+                  ]
+                },
+                {
+                  "kind": "Subscript",
+                  "name": "subscript",
+                  "printedName": "subscript(_:)",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -91488,175 +103069,29 @@
                         }
                       ]
                     }
-                  ]
-                },
-                {
-                  "kind": "Function",
-                  "name": "formIndex",
-                  "printedName": "formIndex(after:)",
-                  "declKind": "Func",
-                  "usr": "s:SS9UTF16ViewV7IndicesV9formIndex5afterySS0E0Vz_tF",
-                  "location": "",
+                  ],
+                  "declKind": "Subscript",
+                  "usr": "s:SS9UTF16ViewV7IndicesVySS5IndexVAFcip",
                   "moduleName": "Swift",
                   "declAttributes": [
                     "Inlinable"
-                  ],
+                  ]
+                },
+                {
+                  "kind": "Subscript",
+                  "name": "subscript",
+                  "printedName": "subscript(_:)",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Void",
-                      "printedName": "()"
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "Function",
-                  "name": "index",
-                  "printedName": "index(before:)",
-                  "declKind": "Func",
-                  "usr": "s:SS9UTF16ViewV7IndicesV5index6beforeSS5IndexVAH_tF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "Function",
-                  "name": "formIndex",
-                  "printedName": "formIndex(before:)",
-                  "declKind": "Func",
-                  "usr": "s:SS9UTF16ViewV7IndicesV9formIndex6beforeySS0E0Vz_tF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Void",
-                      "printedName": "()"
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "Function",
-                  "name": "index",
-                  "printedName": "index(_:offsetBy:)",
-                  "declKind": "Func",
-                  "usr": "s:SS9UTF16ViewV7IndicesV5index_8offsetBySS5IndexVAH_SitF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    },
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Indices.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
+                      "name": "Indices",
+                      "printedName": "String.UTF16View.Indices",
+                      "usr": "s:SS9UTF16ViewV7IndicesV"
                     },
                     {
                       "kind": "TypeNominal",
-                      "name": "Int",
-                      "printedName": "Int",
-                      "usr": "s:Si"
-                    }
-                  ]
-                },
-                {
-                  "kind": "Function",
-                  "name": "index",
-                  "printedName": "index(_:offsetBy:limitedBy:)",
-                  "declKind": "Func",
-                  "usr": "s:SS9UTF16ViewV7IndicesV5index_8offsetBy07limitedF0SS5IndexVSgAI_SiAItF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Optional",
-                      "printedName": "String.UTF16View.Indices.Index?",
-                      "usr": "s:Sq",
+                      "name": "Range",
+                      "printedName": "Range<String.UTF16View.Indices.Index>",
                       "children": [
                         {
                           "kind": "TypeNameAlias",
@@ -91671,6 +103106,33 @@
                             }
                           ]
                         }
+                      ],
+                      "usr": "s:Sn"
+                    }
+                  ],
+                  "declKind": "Subscript",
+                  "usr": "s:SS9UTF16ViewV7IndicesVyADSnySS5IndexVGcip",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "index",
+                  "printedName": "index(after:)",
+                  "children": [
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Index",
+                      "printedName": "String.UTF16View.Indices.Index",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
                       ]
                     },
                     {
@@ -91685,6 +103147,199 @@
                           "usr": "s:SS5IndexV"
                         }
                       ]
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS9UTF16ViewV7IndicesV5index5afterSS5IndexVAH_tF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "formIndex",
+                  "printedName": "formIndex(after:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Void",
+                      "printedName": "()"
+                    },
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Index",
+                      "printedName": "String.UTF16View.Indices.Index",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
+                      ]
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS9UTF16ViewV7IndicesV9formIndex5afterySS0E0Vz_tF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "index",
+                  "printedName": "index(before:)",
+                  "children": [
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Index",
+                      "printedName": "String.UTF16View.Indices.Index",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
+                      ]
+                    },
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Index",
+                      "printedName": "String.UTF16View.Indices.Index",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
+                      ]
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS9UTF16ViewV7IndicesV5index6beforeSS5IndexVAH_tF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "formIndex",
+                  "printedName": "formIndex(before:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Void",
+                      "printedName": "()"
+                    },
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Index",
+                      "printedName": "String.UTF16View.Indices.Index",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
+                      ]
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS9UTF16ViewV7IndicesV9formIndex6beforeySS0E0Vz_tF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "index",
+                  "printedName": "index(_:offsetBy:)",
+                  "children": [
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Index",
+                      "printedName": "String.UTF16View.Indices.Index",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
+                      ]
+                    },
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Index",
+                      "printedName": "String.UTF16View.Indices.Index",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
+                      ]
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS9UTF16ViewV7IndicesV5index_8offsetBySS5IndexVAH_SitF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Function",
+                  "name": "index",
+                  "printedName": "index(_:offsetBy:limitedBy:)",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Optional",
+                      "printedName": "String.UTF16View.Indices.Index?",
+                      "children": [
+                        {
+                          "kind": "TypeNameAlias",
+                          "name": "Index",
+                          "printedName": "String.UTF16View.Indices.Index",
+                          "children": [
+                            {
+                              "kind": "TypeNominal",
+                              "name": "Index",
+                              "printedName": "String.Index",
+                              "usr": "s:SS5IndexV"
+                            }
+                          ]
+                        }
+                      ],
+                      "usr": "s:Sq"
+                    },
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Index",
+                      "printedName": "String.UTF16View.Indices.Index",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
+                      ]
                     },
                     {
                       "kind": "TypeNominal",
@@ -91705,19 +103360,18 @@
                         }
                       ]
                     }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS9UTF16ViewV7IndicesV5index_8offsetBy07limitedF0SS5IndexVSgAI_SiAItF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
                   "kind": "Function",
                   "name": "distance",
                   "printedName": "distance(from:to:)",
-                  "declKind": "Func",
-                  "usr": "s:SS9UTF16ViewV7IndicesV8distance4from2toSiSS5IndexV_AItF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -91751,16 +103405,18 @@
                         }
                       ]
                     }
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS9UTF16ViewV7IndicesV8distance4from2toSiSS5IndexV_AItF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
                   "kind": "TypeAlias",
                   "name": "Element",
                   "printedName": "Element",
-                  "declKind": "TypeAlias",
-                  "usr": "s:SS9UTF16ViewV7IndicesV7Elementa",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -91775,22 +103431,21 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:SS9UTF16ViewV7IndicesV7Elementa",
+                  "moduleName": "Swift",
+                  "implicit": true
                 },
                 {
                   "kind": "TypeAlias",
                   "name": "Iterator",
                   "printedName": "Iterator",
-                  "declKind": "TypeAlias",
-                  "usr": "s:SS9UTF16ViewV7IndicesV8Iteratora",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "IndexingIterator",
                       "printedName": "IndexingIterator<String.UTF16View.Indices>",
-                      "usr": "s:s16IndexingIteratorV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -91798,23 +103453,32 @@
                           "printedName": "String.UTF16View.Indices",
                           "usr": "s:SS9UTF16ViewV7IndicesV"
                         }
-                      ]
+                      ],
+                      "usr": "s:s16IndexingIteratorV"
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:SS9UTF16ViewV7IndicesV8Iteratora",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
+              ],
+              "declKind": "Struct",
+              "usr": "s:SS9UTF16ViewV7IndicesV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "BidirectionalCollection",
+                "Collection",
+                "Sequence"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:SS9UTF16ViewV7indicesAB7IndicesVvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -91826,10 +103490,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS9UTF16ViewV7indicesAB7IndicesVvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -91837,21 +103497,23 @@
                       "printedName": "String.UTF16View.Indices",
                       "usr": "s:SS9UTF16ViewV7IndicesV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS9UTF16ViewV7indicesAB7IndicesVvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS9UTF16ViewV7indicesAB7IndicesVvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SS9UTF16ViewV5index5afterSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -91879,19 +103541,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS9UTF16ViewV5index5afterSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:SS9UTF16ViewV5index6beforeSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -91919,19 +103580,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS9UTF16ViewV5index6beforeSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(_:offsetBy:)",
-              "declKind": "Func",
-              "usr": "s:SS9UTF16ViewV5index_8offsetBySS5IndexVAF_SitF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -91965,25 +103625,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS9UTF16ViewV5index_8offsetBySS5IndexVAF_SitF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(_:offsetBy:limitedBy:)",
-              "declKind": "Func",
-              "usr": "s:SS9UTF16ViewV5index_8offsetBy07limitedE0SS5IndexVSgAG_SiAGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "String.UTF16View.Index?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -91998,7 +103656,8 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNameAlias",
@@ -92032,19 +103691,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS9UTF16ViewV5index_8offsetBy07limitedE0SS5IndexVSgAG_SiAGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "distance",
               "printedName": "distance(from:to:)",
-              "declKind": "Func",
-              "usr": "s:SS9UTF16ViewV8distance4from2toSiSS5IndexV_AGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -92078,16 +103736,57 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS9UTF16ViewV8distance4from2toSiSS5IndexV_AGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "CodeUnit",
+                  "printedName": "UTF16.CodeUnit",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt16",
+                      "printedName": "UInt16",
+                      "usr": "s:s6UInt16V"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "String.UTF16View.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ]
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SS9UTF16ViewVys6UInt16VSS5IndexVcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "description",
               "printedName": "description",
-              "declKind": "Var",
-              "usr": "s:SS9UTF16ViewV11descriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -92099,10 +103798,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS9UTF16ViewV11descriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -92110,18 +103805,20 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS9UTF16ViewV11descriptionSSvg",
+                  "moduleName": "Swift"
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:SS9UTF16ViewV11descriptionSSvp",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "debugDescription",
               "printedName": "debugDescription",
-              "declKind": "Var",
-              "usr": "s:SS9UTF16ViewV16debugDescriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -92133,10 +103830,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS9UTF16ViewV16debugDescriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -92144,18 +103837,20 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS9UTF16ViewV16debugDescriptionSSvg",
+                  "moduleName": "Swift"
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:SS9UTF16ViewV16debugDescriptionSSvp",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:SS9UTF16ViewV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -92170,22 +103865,21 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SS9UTF16ViewV7Elementa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:SS9UTF16ViewV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "IndexingIterator",
                   "printedName": "IndexingIterator<String.UTF16View>",
-                  "usr": "s:s16IndexingIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -92193,18 +103887,19 @@
                       "printedName": "String.UTF16View",
                       "usr": "s:SS9UTF16ViewV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s16IndexingIteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SS9UTF16ViewV8Iteratora",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Var",
               "name": "customMirror",
               "printedName": "customMirror",
-              "declKind": "Var",
-              "usr": "s:SS9UTF16ViewV12customMirrors0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -92216,10 +103911,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS9UTF16ViewV12customMirrors0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -92227,18 +103918,20 @@
                       "printedName": "Mirror",
                       "usr": "s:s6MirrorV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS9UTF16ViewV12customMirrors0D0Vvg",
+                  "moduleName": "Swift"
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:SS9UTF16ViewV12customMirrors0D0Vvp",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:SS9UTF16ViewV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -92246,38 +103939,33 @@
                   "printedName": "Substring.UTF16View",
                   "usr": "s:Ss9UTF16ViewV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SS9UTF16ViewV11SubSequencea",
+              "moduleName": "Swift"
             },
             {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SS9UTF16ViewV5index5afterSS5IndexVAFSg_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Available"
-              ],
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
               "children": [
                 {
                   "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF16View.Index",
+                  "name": "SubSequence",
+                  "printedName": "String.UTF16View.SubSequence",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
+                      "name": "UTF16View",
+                      "printedName": "Substring.UTF16View",
+                      "usr": "s:Ss9UTF16ViewV"
                     }
                   ]
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF16View.Index?",
-                  "usr": "s:Sq",
+                  "name": "Range",
+                  "printedName": "Range<String.UTF16View.Index>",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -92292,138 +103980,22 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(_:offsetBy:)",
-              "declKind": "Func",
-              "usr": "s:SS9UTF16ViewV5index_8offsetBySS5IndexVAFSg_SitF",
-              "location": "",
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SS9UTF16ViewVySsAAVSnySS5IndexVGcip",
               "moduleName": "Swift",
               "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF16View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF16View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "distance",
-              "printedName": "distance(from:to:)",
-              "declKind": "Func",
-              "usr": "s:SS9UTF16ViewV8distance4from2toSiSS5IndexVSg_AHtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF16View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF16View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF16View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
+                "Available",
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "customPlaygroundQuickLook",
               "printedName": "customPlaygroundQuickLook",
-              "declKind": "Var",
-              "usr": "s:SS9UTF16ViewV25customPlaygroundQuickLooks01_deF0Ovp",
-              "location": "",
-              "moduleName": "Swift",
-              "deprecated": true,
-              "declAttributes": [
-                "Available"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -92435,10 +104007,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS9UTF16ViewV25customPlaygroundQuickLooks01_deF0Ovg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -92446,23 +104014,42 @@
                       "printedName": "_PlaygroundQuickLook",
                       "usr": "s:s20_PlaygroundQuickLookO"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS9UTF16ViewV25customPlaygroundQuickLooks01_deF0Ovg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS9UTF16ViewV25customPlaygroundQuickLooks01_deF0Ovp",
+              "moduleName": "Swift",
+              "deprecated": true,
+              "declAttributes": [
+                "Available"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SS9UTF16ViewV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "BidirectionalCollection",
+            "CustomStringConvertible",
+            "CustomDebugStringConvertible",
+            "Collection",
+            "Sequence",
+            "_SwiftStringView",
+            "CustomReflectable",
+            "_CustomPlaygroundQuickLookable"
           ]
         },
         {
           "kind": "Var",
           "name": "utf16",
           "printedName": "utf16",
-          "declKind": "Var",
-          "usr": "s:SS5utf16SS9UTF16ViewVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -92474,10 +104061,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS5utf16SS9UTF16ViewVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -92485,17 +104068,15 @@
                   "printedName": "String.UTF16View",
                   "usr": "s:SS9UTF16ViewV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS5utf16SS9UTF16ViewVvg",
+              "moduleName": "Swift"
             },
             {
               "kind": "Setter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS5utf16SS9UTF16ViewVvs",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -92508,18 +104089,50 @@
                   "printedName": "String.UTF16View",
                   "usr": "s:SS9UTF16ViewV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS5utf16SS9UTF16ViewVvs",
+              "moduleName": "Swift",
+              "mutating": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS5utf16SS9UTF16ViewVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UTF16View",
+              "printedName": "String.UTF16View",
+              "usr": "s:SS9UTF16ViewV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSyS2S9UTF16ViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Available",
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "UTF16Index",
           "printedName": "UTF16Index",
-          "declKind": "TypeAlias",
-          "usr": "s:SS10UTF16Indexa",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -92534,38 +104147,20 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SS10UTF16Indexa",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeDecl",
           "name": "UTF8View",
           "printedName": "UTF8View",
-          "declKind": "Struct",
-          "usr": "s:SS8UTF8ViewV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "CustomStringConvertible",
-            "CustomDebugStringConvertible",
-            "Collection",
-            "Sequence",
-            "_SwiftStringView",
-            "CustomReflectable",
-            "_CustomPlaygroundQuickLookable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Index",
               "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:SS8UTF8ViewV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -92573,19 +104168,15 @@
                   "printedName": "String.Index",
                   "usr": "s:SS5IndexV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SS8UTF8ViewV5Indexa",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:SS8UTF8ViewV10startIndexSS0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -92604,10 +104195,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS8UTF8ViewV10startIndexSS0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -92622,21 +104209,23 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS8UTF8ViewV10startIndexSS0D0Vvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS8UTF8ViewV10startIndexSS0D0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:SS8UTF8ViewV8endIndexSS0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -92655,10 +104244,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS8UTF8ViewV8endIndexSS0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -92673,22 +104258,23 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS8UTF8ViewV8endIndexSS0D0Vvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS8UTF8ViewV8endIndexSS0D0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SS8UTF8ViewV5index5afterSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inline",
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -92716,19 +104302,19 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS8UTF8ViewV5index5afterSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:SS8UTF8ViewV5index6beforeSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -92756,19 +104342,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS8UTF8ViewV5index6beforeSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "distance",
               "printedName": "distance(from:to:)",
-              "declKind": "Func",
-              "usr": "s:SS8UTF8ViewV8distance4from2toSiSS5IndexV_AGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -92802,19 +104387,57 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:SS8UTF8ViewV8distance4from2toSiSS5IndexV_AGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "CodeUnit",
+                  "printedName": "UTF8.CodeUnit",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt8",
+                      "printedName": "UInt8",
+                      "usr": "s:s5UInt8V"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "String.UTF8View.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ]
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SS8UTF8ViewVys5UInt8VSS5IndexVcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "description",
               "printedName": "description",
-              "declKind": "Var",
-              "usr": "s:SS8UTF8ViewV11descriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -92826,10 +104449,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS8UTF8ViewV11descriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -92837,18 +104456,23 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS8UTF8ViewV11descriptionSSvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS8UTF8ViewV11descriptionSSvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "debugDescription",
               "printedName": "debugDescription",
-              "declKind": "Var",
-              "usr": "s:SS8UTF8ViewV16debugDescriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -92860,10 +104484,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS8UTF8ViewV16debugDescriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -92871,18 +104491,20 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS8UTF8ViewV16debugDescriptionSSvg",
+                  "moduleName": "Swift"
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:SS8UTF8ViewV16debugDescriptionSSvp",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:SS8UTF8ViewV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -92897,22 +104519,21 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SS8UTF8ViewV7Elementa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Indices",
               "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:SS8UTF8ViewV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DefaultIndices",
                   "printedName": "DefaultIndices<String.UTF8View>",
-                  "usr": "s:SI",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -92920,33 +104541,24 @@
                       "printedName": "String.UTF8View",
                       "usr": "s:SS8UTF8ViewV"
                     }
-                  ]
+                  ],
+                  "usr": "s:SI"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SS8UTF8ViewV7Indicesa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeDecl",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "Struct",
-              "usr": "s:SS8UTF8ViewV8IteratorV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "IteratorProtocol"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
               "children": [
                 {
                   "kind": "TypeAlias",
                   "name": "Element",
                   "printedName": "Element",
-                  "declKind": "TypeAlias",
-                  "usr": "s:SS8UTF8ViewV8IteratorV7Elementa",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -92961,19 +104573,15 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:SS8UTF8ViewV8IteratorV7Elementa",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init(_:)",
-                  "declKind": "Constructor",
-                  "usr": "s:SS8UTF8ViewV8IteratorVyAdBcfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -92987,27 +104595,24 @@
                       "printedName": "String.UTF8View",
                       "usr": "s:SS8UTF8ViewV"
                     }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:SS8UTF8ViewV8IteratorVyAdBcfc",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
                   "kind": "Function",
                   "name": "next",
                   "printedName": "next()",
-                  "declKind": "Func",
-                  "usr": "s:SS8UTF8ViewV8IteratorV4nexts5UInt8VSgyF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "mutating": true,
-                  "declAttributes": [
-                    "Inline",
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
                       "printedName": "Unicode.UTF8.CodeUnit?",
-                      "usr": "s:Sq",
                       "children": [
                         {
                           "kind": "TypeNameAlias",
@@ -93022,20 +104627,34 @@
                             }
                           ]
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     }
-                  ]
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:SS8UTF8ViewV8IteratorV4nexts5UInt8VSgyF",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inline",
+                    "Inlinable"
+                  ],
+                  "mutating": true
                 }
+              ],
+              "declKind": "Struct",
+              "usr": "s:SS8UTF8ViewV8IteratorV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "IteratorProtocol"
               ]
             },
             {
               "kind": "Function",
               "name": "makeIterator",
               "printedName": "makeIterator()",
-              "declKind": "Func",
-              "usr": "s:SS8UTF8ViewV12makeIteratorAB0D0VyF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -93043,19 +104662,15 @@
                   "printedName": "String.UTF8View.Iterator",
                   "usr": "s:SS8UTF8ViewV8IteratorV"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:SS8UTF8ViewV12makeIteratorAB0D0VyF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "count",
               "printedName": "count",
-              "declKind": "Var",
-              "usr": "s:SS8UTF8ViewV5countSivp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -93067,10 +104682,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS8UTF8ViewV5countSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -93078,18 +104689,23 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS8UTF8ViewV5countSivg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS8UTF8ViewV5countSivp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "customMirror",
               "printedName": "customMirror",
-              "declKind": "Var",
-              "usr": "s:SS8UTF8ViewV12customMirrors0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -93101,10 +104717,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS8UTF8ViewV12customMirrors0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -93112,18 +104724,20 @@
                       "printedName": "Mirror",
                       "usr": "s:s6MirrorV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS8UTF8ViewV12customMirrors0D0Vvg",
+                  "moduleName": "Swift"
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:SS8UTF8ViewV12customMirrors0D0Vvp",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:SS8UTF8ViewV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -93131,38 +104745,33 @@
                   "printedName": "Substring.UTF8View",
                   "usr": "s:Ss8UTF8ViewV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SS8UTF8ViewV11SubSequencea",
+              "moduleName": "Swift"
             },
             {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:SS8UTF8ViewV5index5afterSS5IndexVAFSg_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Available"
-              ],
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
               "children": [
                 {
                   "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF8View.Index",
+                  "name": "SubSequence",
+                  "printedName": "String.UTF8View.SubSequence",
                   "children": [
                     {
                       "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
+                      "name": "UTF8View",
+                      "printedName": "Substring.UTF8View",
+                      "usr": "s:Ss8UTF8ViewV"
                     }
                   ]
                 },
                 {
                   "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF8View.Index?",
-                  "usr": "s:Sq",
+                  "name": "Range",
+                  "printedName": "Range<String.UTF8View.Index>",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -93177,138 +104786,22 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "index",
-              "printedName": "index(_:offsetBy:)",
-              "declKind": "Func",
-              "usr": "s:SS8UTF8ViewV5index_8offsetBySS5IndexVAFSg_SitF",
-              "location": "",
+              ],
+              "declKind": "Subscript",
+              "usr": "s:SS8UTF8ViewVySsAAVSnySS5IndexVGcip",
               "moduleName": "Swift",
               "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Index",
-                  "printedName": "String.UTF8View.Index",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Index",
-                      "printedName": "String.Index",
-                      "usr": "s:SS5IndexV"
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF8View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF8View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            },
-            {
-              "kind": "Function",
-              "name": "distance",
-              "printedName": "distance(from:to:)",
-              "declKind": "Func",
-              "usr": "s:SS8UTF8ViewV8distance4from2toSiSS5IndexVSg_AHtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Available"
-              ],
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF8View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF8View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "Optional",
-                  "printedName": "String.UTF8View.Index?",
-                  "usr": "s:Sq",
-                  "children": [
-                    {
-                      "kind": "TypeNameAlias",
-                      "name": "Index",
-                      "printedName": "String.UTF8View.Index",
-                      "children": [
-                        {
-                          "kind": "TypeNominal",
-                          "name": "Index",
-                          "printedName": "String.Index",
-                          "usr": "s:SS5IndexV"
-                        }
-                      ]
-                    }
-                  ]
-                }
+                "Available",
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "customPlaygroundQuickLook",
               "printedName": "customPlaygroundQuickLook",
-              "declKind": "Var",
-              "usr": "s:SS8UTF8ViewV25customPlaygroundQuickLooks01_deF0Ovp",
-              "location": "",
-              "moduleName": "Swift",
-              "deprecated": true,
-              "declAttributes": [
-                "Available"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -93320,10 +104813,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:SS8UTF8ViewV25customPlaygroundQuickLooks01_deF0Ovg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -93331,23 +104820,42 @@
                       "printedName": "_PlaygroundQuickLook",
                       "usr": "s:s20_PlaygroundQuickLookO"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:SS8UTF8ViewV25customPlaygroundQuickLooks01_deF0Ovg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:SS8UTF8ViewV25customPlaygroundQuickLooks01_deF0Ovp",
+              "moduleName": "Swift",
+              "deprecated": true,
+              "declAttributes": [
+                "Available"
               ]
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SS8UTF8ViewV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "BidirectionalCollection",
+            "CustomStringConvertible",
+            "CustomDebugStringConvertible",
+            "Collection",
+            "Sequence",
+            "_SwiftStringView",
+            "CustomReflectable",
+            "_CustomPlaygroundQuickLookable"
           ]
         },
         {
           "kind": "Var",
           "name": "utf8",
           "printedName": "utf8",
-          "declKind": "Var",
-          "usr": "s:SS4utf8SS8UTF8ViewVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -93359,10 +104867,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS4utf8SS8UTF8ViewVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -93370,17 +104874,15 @@
                   "printedName": "String.UTF8View",
                   "usr": "s:SS8UTF8ViewV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS4utf8SS8UTF8ViewVvg",
+              "moduleName": "Swift"
             },
             {
               "kind": "Setter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS4utf8SS8UTF8ViewVvs",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -93393,24 +104895,29 @@
                   "printedName": "String.UTF8View",
                   "usr": "s:SS8UTF8ViewV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS4utf8SS8UTF8ViewVvs",
+              "moduleName": "Swift",
+              "mutating": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS4utf8SS8UTF8ViewVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "utf8CString",
           "printedName": "utf8CString",
-          "declKind": "Var",
-          "usr": "s:SS11utf8CStrings15ContiguousArrayVys4Int8VGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "ContiguousArray",
               "printedName": "ContiguousArray<CChar>",
-              "usr": "s:s15ContiguousArrayV",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -93425,22 +104932,18 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:s15ContiguousArrayV"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS11utf8CStrings15ContiguousArrayVys4Int8VGvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ContiguousArray",
                   "printedName": "ContiguousArray<CChar>",
-                  "usr": "s:s15ContiguousArrayV",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -93455,20 +104958,49 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:s15ContiguousArrayV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS11utf8CStrings15ContiguousArrayVys4Int8VGvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS11utf8CStrings15ContiguousArrayVys4Int8VGvp",
+          "moduleName": "Swift"
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "String",
+              "printedName": "String",
+              "usr": "s:SS"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UTF8View",
+              "printedName": "String.UTF8View",
+              "usr": "s:SS8UTF8ViewV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSyS2S8UTF8ViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Available",
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "UTF8Index",
           "printedName": "UTF8Index",
-          "declKind": "TypeAlias",
-          "usr": "s:SS9UTF8Indexa",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -93483,16 +105015,15 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SS9UTF8Indexa",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSSscfc",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -93506,25 +105037,20 @@
               "printedName": "Substring",
               "usr": "s:Ss"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSySSSscfc",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSSgSs8UTF8ViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "String?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -93532,7 +105058,8 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -93540,25 +105067,23 @@
               "printedName": "Substring.UTF8View",
               "usr": "s:Ss8UTF8ViewV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSySSSgSs8UTF8ViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSSgSs9UTF16ViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "String?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -93566,7 +105091,8 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -93574,19 +105100,18 @@
               "printedName": "Substring.UTF16View",
               "usr": "s:Ss9UTF16ViewV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSySSSgSs9UTF16ViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSSs17UnicodeScalarViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -93600,20 +105125,52 @@
               "printedName": "Substring.UnicodeScalarView",
               "usr": "s:Ss17UnicodeScalarViewV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SSySSSs17UnicodeScalarViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<String.Index>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SSySsSnySS5IndexVGcip",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Available",
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "CharacterView",
           "printedName": "CharacterView",
-          "declKind": "TypeAlias",
-          "usr": "s:SS13CharacterViewa",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -93621,20 +105178,19 @@
               "printedName": "String",
               "usr": "s:SS"
             }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SS13CharacterViewa",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Var",
           "name": "characters",
           "printedName": "characters",
-          "declKind": "Var",
-          "usr": "s:SS10charactersSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -93646,10 +105202,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS10charactersSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -93657,17 +105209,15 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS10charactersSSvg",
+              "moduleName": "Swift"
             },
             {
               "kind": "Setter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SS10charactersSSvs",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -93680,24 +105230,25 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SS10charactersSSvs",
+              "moduleName": "Swift",
+              "mutating": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SS10charactersSSvp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "withMutableCharacters",
           "printedName": "withMutableCharacters(_:)",
-          "declKind": "Func",
-          "usr": "s:SS21withMutableCharactersyxxSSzXElF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<R>",
-          "deprecated": true,
-          "mutating": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -93708,9 +105259,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(inout String) -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -93729,170 +105277,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSSgSS9UTF16ViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "String?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UTF16View",
-              "printedName": "String.UTF16View",
-              "usr": "s:SS9UTF16ViewV"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SSySSSgSS8UTF8ViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available",
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "String?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "UTF8View",
-              "printedName": "String.UTF8View",
-              "usr": "s:SS8UTF8ViewV"
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:obsoletedInSwift4:)",
-          "declKind": "Constructor",
-          "usr": "s:SS_17obsoletedInSwift4SSSgSS_yttcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "String?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "String",
-                  "printedName": "String",
-                  "usr": "s:SS"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "String",
-              "printedName": "String",
-              "usr": "s:SS"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Void",
-              "printedName": "()",
-              "hasDefaultArg": true
-            }
-          ]
-        },
-        {
-          "kind": "Function",
-          "name": "popFirst",
-          "printedName": "popFirst()",
           "declKind": "Func",
-          "usr": "s:SS8popFirstSJSgyF",
-          "location": "",
+          "usr": "s:SS21withMutableCharactersyxxSSzXElF",
           "moduleName": "Swift",
+          "genericSig": "<R>",
           "deprecated": true,
-          "mutating": true,
           "declAttributes": [
             "Available"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "String.Element?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNameAlias",
-                  "name": "Element",
-                  "printedName": "String.Element",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "Character",
-                      "printedName": "Character",
-                      "usr": "s:SJ"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
+          "mutating": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(describing:)",
-          "declKind": "Constructor",
-          "usr": "s:SS10describingSSx_tclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Subject>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -93905,20 +105309,16 @@
               "name": "GenericTypeParam",
               "printedName": "Subject"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS10describingSSx_tclufc",
+          "moduleName": "Swift",
+          "genericSig": "<Subject>"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(reflecting:)",
-          "declKind": "Constructor",
-          "usr": "s:SS10reflectingSSx_tclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Subject>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -93931,43 +105331,103 @@
               "name": "GenericTypeParam",
               "printedName": "Subject"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SS10reflectingSSx_tclufc",
+          "moduleName": "Swift",
+          "genericSig": "<Subject>"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:SS",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Encodable",
+        "Decodable",
+        "CustomReflectable",
+        "_CustomPlaygroundQuickLookable",
+        "TextOutputStream",
+        "TextOutputStreamable",
+        "Hashable",
+        "_ExpressibleByBuiltinUnicodeScalarLiteral",
+        "_ExpressibleByBuiltinExtendedGraphemeClusterLiteral",
+        "_ExpressibleByBuiltinUTF16StringLiteral",
+        "_ExpressibleByBuiltinStringLiteral",
+        "ExpressibleByStringLiteral",
+        "ExpressibleByExtendedGraphemeClusterLiteral",
+        "ExpressibleByUnicodeScalarLiteral",
+        "CustomDebugStringConvertible",
+        "CustomStringConvertible",
+        "BidirectionalCollection",
+        "Collection",
+        "Sequence",
+        "Equatable",
+        "Comparable",
+        "_SwiftStringView",
+        "_ExpressibleByStringInterpolation",
+        "StringProtocol",
+        "RangeReplaceableCollection",
+        "LosslessStringConvertible",
+        "MirrorPath"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "StringProtocol",
       "printedName": "StringProtocol",
-      "declKind": "Protocol",
-      "usr": "s:Sy",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : BidirectionalCollection, Self : Comparable, Self : ExpressibleByStringLiteral, Self : Hashable, Self : LosslessStringConvertible, Self : TextOutputStream, Self : TextOutputStreamable, Self.Element == Character, Self.SubSequence : StringProtocol, Self.UTF16View : BidirectionalCollection, Self.UTF8View : Collection, Self.UnicodeScalarView : BidirectionalCollection, Self.UTF16View.Element == UInt16, Self.UTF8View.Element == UInt8, Self.UnicodeScalarView.Element == Unicode.Scalar>",
-      "conformingProtocols": [
-        "BidirectionalCollection",
-        "TextOutputStream",
-        "TextOutputStreamable",
-        "LosslessStringConvertible",
-        "ExpressibleByStringLiteral",
-        "Hashable",
-        "Comparable",
-        "Collection",
-        "CustomStringConvertible",
-        "ExpressibleByExtendedGraphemeClusterLiteral",
-        "Equatable",
-        "Sequence",
-        "ExpressibleByUnicodeScalarLiteral"
-      ],
       "children": [
         {
+          "kind": "AssociatedType",
+          "name": "UTF8View",
+          "printedName": "UTF8View",
+          "declKind": "AssociatedType",
+          "usr": "s:Sy8UTF8ViewQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "UTF16View",
+          "printedName": "UTF16View",
+          "declKind": "AssociatedType",
+          "usr": "s:Sy9UTF16ViewQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "UnicodeScalarView",
+          "printedName": "UnicodeScalarView",
+          "declKind": "AssociatedType",
+          "usr": "s:Sy17UnicodeScalarViewQa",
+          "moduleName": "Swift",
+          "protocolReq": true
+        },
+        {
+          "kind": "AssociatedType",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            }
+          ],
+          "declKind": "AssociatedType",
+          "usr": "s:Sy11SubSequenceQa",
+          "moduleName": "Swift",
+          "protocolReq": true,
+          "overriding": true
+        },
+        {
           "kind": "Var",
           "name": "utf8",
           "printedName": "utf8",
-          "declKind": "Var",
-          "usr": "s:Sy4utf88UTF8ViewQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -93978,29 +105438,28 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sy4utf88UTF8ViewQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : StringProtocol>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.UTF8View"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sy4utf88UTF8ViewQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : StringProtocol>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sy4utf88UTF8ViewQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "utf16",
           "printedName": "utf16",
-          "declKind": "Var",
-          "usr": "s:Sy5utf169UTF16ViewQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -94011,29 +105470,28 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sy5utf169UTF16ViewQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : StringProtocol>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.UTF16View"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sy5utf169UTF16ViewQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : StringProtocol>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sy5utf169UTF16ViewQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Var",
           "name": "unicodeScalars",
           "printedName": "unicodeScalars",
-          "declKind": "Var",
-          "usr": "s:Sy14unicodeScalars17UnicodeScalarViewQzvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -94044,30 +105502,28 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sy14unicodeScalars17UnicodeScalarViewQzvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : StringProtocol>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.UnicodeScalarView"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sy14unicodeScalars17UnicodeScalarViewQzvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : StringProtocol>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sy14unicodeScalars17UnicodeScalarViewQzvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "hasPrefix",
           "printedName": "hasPrefix(_:)",
-          "declKind": "Func",
-          "usr": "s:Sy9hasPrefixySbSSF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -94081,17 +105537,17 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sy9hasPrefixySbSSF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : StringProtocol>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "hasSuffix",
           "printedName": "hasSuffix(_:)",
-          "declKind": "Func",
-          "usr": "s:Sy9hasSuffixySbSSF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -94105,17 +105561,17 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sy9hasSuffixySbSSF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : StringProtocol>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "lowercased",
           "printedName": "lowercased()",
-          "declKind": "Func",
-          "usr": "s:Sy10lowercasedSSyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -94123,17 +105579,17 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sy10lowercasedSSyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : StringProtocol>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "uppercased",
           "printedName": "uppercased()",
-          "declKind": "Func",
-          "usr": "s:Sy10uppercasedSSyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -94141,17 +105597,17 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sy10uppercasedSSyF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : StringProtocol>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(decoding:as:)",
-          "declKind": "Constructor",
-          "usr": "s:Sy8decoding2asxqd___qd_0_mtcSlRd__s16_UnicodeEncodingRd_0_8CodeUnitQyd_0_7ElementRtd__r0_lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, C, Encoding where Self : StringProtocol, C : Collection, Encoding : _UnicodeEncoding, C.Element == Encoding.CodeUnit>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -94175,17 +105631,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sy8decoding2asxqd___qd_0_mtcSlRd__s16_UnicodeEncodingRd_0_8CodeUnitQyd_0_7ElementRtd__r0_lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, C, Encoding where Self : StringProtocol, C : Collection, Encoding : _UnicodeEncoding, C.Element == Encoding.CodeUnit>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(cString:)",
-          "declKind": "Constructor",
-          "usr": "s:Sy7cStringxSPys4Int8VG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -94196,7 +105652,6 @@
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<CChar>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -94211,19 +105666,20 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:SP"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sy7cStringxSPys4Int8VG_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : StringProtocol>",
+          "protocolReq": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(decodingCString:as:)",
-          "declKind": "Constructor",
-          "usr": "s:Sy15decodingCString2asxSPy8CodeUnitQyd__G_qd__mtcs16_UnicodeEncodingRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Encoding where Self : StringProtocol, Encoding : _UnicodeEncoding>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -94234,14 +105690,14 @@
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<Encoding.CodeUnit>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Encoding.CodeUnit"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             },
             {
               "kind": "TypeNominal",
@@ -94255,21 +105711,17 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sy15decodingCString2asxSPy8CodeUnitQyd__G_qd__mtcs16_UnicodeEncodingRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Encoding where Self : StringProtocol, Encoding : _UnicodeEncoding>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "withCString",
           "printedName": "withCString(_:)",
-          "declKind": "Func",
-          "usr": "s:Sy11withCStringyqd__qd__SPys4Int8VGKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Result where Self : StringProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -94280,9 +105732,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafePointer<CChar>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -94293,13 +105742,11 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafePointer<CChar>)",
-                  "usr": "s:SP",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafePointer",
                       "printedName": "UnsafePointer<CChar>",
-                      "usr": "s:SP",
                       "children": [
                         {
                           "kind": "TypeNameAlias",
@@ -94314,27 +105761,32 @@
                             }
                           ]
                         }
-                      ]
+                      ],
+                      "usr": "s:SP"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sy11withCStringyqd__qd__SPys4Int8VGKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Result where Self : StringProtocol>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "withCString",
           "printedName": "withCString(encodedAs:_:)",
-          "declKind": "Func",
-          "usr": "s:Sy11withCString9encodedAs_qd__qd_0_m_qd__SPy8CodeUnitQyd_0_GKXEtKs16_UnicodeEncodingRd_0_r0_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Result, Encoding where Self : StringProtocol, Encoding : _UnicodeEncoding>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -94357,9 +105809,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafePointer<Encoding.CodeUnit>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -94370,39 +105819,43 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafePointer<Encoding.CodeUnit>)",
-                  "usr": "s:SP",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafePointer",
                       "printedName": "UnsafePointer<Encoding.CodeUnit>",
-                      "usr": "s:SP",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "DependentMember",
                           "printedName": "Encoding.CodeUnit"
                         }
-                      ]
+                      ],
+                      "usr": "s:SP"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sy11withCString9encodedAs_qd__qd_0_m_qd__SPy8CodeUnitQyd_0_GKXEtKs16_UnicodeEncodingRd_0_r0_lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Result, Encoding where Self : StringProtocol, Encoding : _UnicodeEncoding>",
+          "protocolReq": true,
+          "declAttributes": [
+            "Rethrows"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "hash",
           "printedName": "hash(into:)",
-          "declKind": "Func",
-          "usr": "s:SysE4hash4intoys6HasherVz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -94415,20 +105868,205 @@
               "printedName": "Hasher",
               "usr": "s:s6HasherV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SysE4hash4intoys6HasherVz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : StringProtocol>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "S"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SysE2eeoiySbx_qd__tSyRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, S where Self : StringProtocol, S : StringProtocol>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "!=",
+          "printedName": "!=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "S"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SysE2neoiySbx_qd__tSyRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, S where Self : StringProtocol, S : StringProtocol>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "R"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SysE1loiySbx_qd__tSyRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, R where Self : StringProtocol, R : StringProtocol>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">",
+          "printedName": ">(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "R"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SysE1goiySbx_qd__tSyRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, R where Self : StringProtocol, R : StringProtocol>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<=",
+          "printedName": "<=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "R"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SysE2leoiySbx_qd__tSyRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, R where Self : StringProtocol, R : StringProtocol>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": ">=",
+          "printedName": ">=(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Self"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "R"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:SysE2geoiySbx_qd__tSyRd__lFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self, R where Self : StringProtocol, R : StringProtocol>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hasPrefix",
           "printedName": "hasPrefix(_:)",
-          "declKind": "Func",
-          "usr": "s:SysE9hasPrefixySbqd__SyRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Prefix where Self : StringProtocol, Prefix : StringProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -94441,20 +106079,19 @@
               "name": "GenericTypeParam",
               "printedName": "Prefix"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SysE9hasPrefixySbqd__SyRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, Prefix where Self : StringProtocol, Prefix : StringProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "hasSuffix",
           "printedName": "hasSuffix(_:)",
-          "declKind": "Func",
-          "usr": "s:SysE9hasSuffixySbqd__SyRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, Suffix where Self : StringProtocol, Suffix : StringProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -94467,114 +106104,45 @@
               "name": "GenericTypeParam",
               "printedName": "Suffix"
             }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "UTF8Index",
-          "printedName": "UTF8Index",
-          "declKind": "TypeAlias",
-          "usr": "s:SysE9UTF8Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.UTF8View.Index"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "UTF16Index",
-          "printedName": "UTF16Index",
-          "declKind": "TypeAlias",
-          "usr": "s:SysE10UTF16Indexa",
-          "location": "",
+          "declKind": "Func",
+          "usr": "s:SysE9hasSuffixySbqd__SyRd__lF",
           "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
-          "deprecated": true,
+          "genericSig": "<Self, Suffix where Self : StringProtocol, Suffix : StringProtocol>",
           "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.UTF16View.Index"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "UnicodeScalarIndex",
-          "printedName": "UnicodeScalarIndex",
-          "declKind": "TypeAlias",
-          "usr": "s:SysE18UnicodeScalarIndexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : StringProtocol>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DependentMember",
-              "printedName": "Self.UnicodeScalarView.Index"
-            }
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:Sy",
+      "moduleName": "Swift",
+      "genericSig": "<Self : BidirectionalCollection, Self : Comparable, Self : ExpressibleByStringLiteral, Self : Hashable, Self : LosslessStringConvertible, Self : TextOutputStream, Self : TextOutputStreamable, Self.Element == Character, Self.SubSequence : StringProtocol, Self.UTF16View : BidirectionalCollection, Self.UTF8View : Collection, Self.UnicodeScalarView : BidirectionalCollection, Self.UTF16View.Element == UInt16, Self.UTF8View.Element == UInt8, Self.UnicodeScalarView.Element == Unicode.Scalar>",
+      "conformingProtocols": [
+        "BidirectionalCollection",
+        "TextOutputStream",
+        "TextOutputStreamable",
+        "LosslessStringConvertible",
+        "ExpressibleByStringLiteral",
+        "Hashable",
+        "Comparable",
+        "Collection",
+        "CustomStringConvertible",
+        "ExpressibleByExtendedGraphemeClusterLiteral",
+        "Equatable",
+        "Sequence",
+        "ExpressibleByUnicodeScalarLiteral"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Substring",
       "printedName": "Substring",
-      "declKind": "Struct",
-      "usr": "s:Ss",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "StringProtocol",
-        "BidirectionalCollection",
-        "Hashable",
-        "Comparable",
-        "Collection",
-        "Sequence",
-        "Equatable",
-        "_SwiftStringView",
-        "CustomReflectable",
-        "CustomStringConvertible",
-        "CustomDebugStringConvertible",
-        "LosslessStringConvertible",
-        "RangeReplaceableCollection",
-        "TextOutputStream",
-        "TextOutputStreamable",
-        "ExpressibleByUnicodeScalarLiteral",
-        "ExpressibleByExtendedGraphemeClusterLiteral",
-        "ExpressibleByStringLiteral",
-        "_CustomPlaygroundQuickLookable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss5Indexa",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -94582,16 +106150,15 @@
               "printedName": "String.Index",
               "usr": "s:SS5IndexV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Ss5Indexa",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -94599,19 +106166,15 @@
               "printedName": "Substring",
               "usr": "s:Ss"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Ss11SubSequencea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:S2sycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -94619,19 +106182,18 @@
               "printedName": "Substring",
               "usr": "s:Ss"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:S2sycfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:_:)",
-          "declKind": "Constructor",
-          "usr": "s:SsySss11_StringGutsV_SnySiGtcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -94649,7 +106211,6 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Int>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -94657,21 +106218,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SsySss11_StringGutsV_SnySiGtcfc",
+          "moduleName": "Swift",
+          "isInternal": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:Ss10startIndexSS0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -94690,10 +106252,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss10startIndexSS0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -94708,21 +106266,23 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss10startIndexSS0B0Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss10startIndexSS0B0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:Ss8endIndexSS0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -94741,10 +106301,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss8endIndexSS0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -94759,21 +106315,23 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss8endIndexSS0B0Vvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss8endIndexSS0B0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:Ss5index5afterSS5IndexVAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -94801,19 +106359,18 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss5index5afterSS5IndexVAD_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:Ss5index6beforeSS5IndexVAD_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -94841,19 +106398,18 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss5index6beforeSS5IndexVAD_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:Ss5index_8offsetBySS5IndexVAD_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -94887,25 +106443,23 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss5index_8offsetBySS5IndexVAD_SitF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:Ss5index_8offsetBy07limitedC0SS5IndexVSgAE_SiAEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Substring.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -94920,7 +106474,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -94954,19 +106509,18 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss5index_8offsetBy07limitedC0SS5IndexVSgAE_SiAEtF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:Ss8distance4from2toSiSS5IndexV_AEtF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -95000,21 +106554,50 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss8distance4from2toSiSS5IndexV_AEtF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Character",
+              "printedName": "Character",
+              "usr": "s:SJ"
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "Substring.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Index",
+                  "printedName": "String.Index",
+                  "usr": "s:SS5IndexV"
+                }
+              ]
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SsySJSS5IndexVcip",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "replaceSubrange",
           "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:Ss15replaceSubrange_4withySnySS5IndexVG_xtSlRzSJ7ElementRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<C where C : Collection, C.Element == Character>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -95025,7 +106608,6 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Substring.Index>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -95040,27 +106622,28 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "C"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss15replaceSubrange_4withySnySS5IndexVG_xtSlRzSJ7ElementRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<C where C : Collection, C.Element == Substring.Iterator.Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "replaceSubrange",
           "printedName": "replaceSubrange(_:with:)",
-          "declKind": "Func",
-          "usr": "s:Ss15replaceSubrange_4withySnySS5IndexVG_SstF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -95071,7 +106654,6 @@
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Substring.Index>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -95086,7 +106668,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             },
             {
               "kind": "TypeNominal",
@@ -95094,20 +106677,19 @@
               "printedName": "Substring",
               "usr": "s:Ss"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss15replaceSubrange_4withySnySS5IndexVG_SstF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(decoding:as:)",
-          "declKind": "Constructor",
-          "usr": "s:Ss8decoding2asSsx_q_mtcSlRzs16_UnicodeEncodingR_8CodeUnitQy_7ElementRtzr0_lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<C, Encoding where C : Collection, Encoding : _UnicodeEncoding, C.Element == Encoding.CodeUnit>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -95132,19 +106714,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Ss8decoding2asSsx_q_mtcSlRzs16_UnicodeEncodingR_8CodeUnitQy_7ElementRtzr0_lufc",
+          "moduleName": "Swift",
+          "genericSig": "<C, Encoding where C : Collection, Encoding : _UnicodeEncoding, C.Element == Encoding.CodeUnit>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(cString:)",
-          "declKind": "Constructor",
-          "usr": "s:Ss7cStringSsSPys4Int8VG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -95156,7 +106738,6 @@
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<CChar>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -95171,22 +106752,21 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:SP"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Ss7cStringSsSPys4Int8VG_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(decodingCString:as:)",
-          "declKind": "Constructor",
-          "usr": "s:Ss15decodingCString2asSsSPy8CodeUnitQzG_xmtcs16_UnicodeEncodingRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Encoding where Encoding : _UnicodeEncoding>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -95198,14 +106778,14 @@
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<Encoding.CodeUnit>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Encoding.CodeUnit"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             },
             {
               "kind": "TypeNominal",
@@ -95219,22 +106799,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Ss15decodingCString2asSsSPy8CodeUnitQzG_xmtcs16_UnicodeEncodingRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<Encoding where Encoding : _UnicodeEncoding>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "withCString",
           "printedName": "withCString(_:)",
-          "declKind": "Func",
-          "usr": "s:Ss11withCStringyxxSPys4Int8VGKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Result>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -95245,9 +106822,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafePointer<CChar>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -95258,13 +106832,11 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafePointer<CChar>)",
-                  "usr": "s:SP",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafePointer",
                       "printedName": "UnsafePointer<CChar>",
-                      "usr": "s:SP",
                       "children": [
                         {
                           "kind": "TypeNameAlias",
@@ -95279,28 +106851,32 @@
                             }
                           ]
                         }
-                      ]
+                      ],
+                      "usr": "s:SP"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss11withCStringyxxSPys4Int8VGKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Result>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "withCString",
           "printedName": "withCString(encodedAs:_:)",
-          "declKind": "Func",
-          "usr": "s:Ss11withCString9encodedAs_xq_m_xSPy8CodeUnitQy_GKXEtKs16_UnicodeEncodingR_r0_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Result, TargetEncoding where TargetEncoding : _UnicodeEncoding>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -95323,9 +106899,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafePointer<TargetEncoding.CodeUnit>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -95336,35 +106909,43 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafePointer<TargetEncoding.CodeUnit>)",
-                  "usr": "s:SP",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafePointer",
                       "printedName": "UnsafePointer<TargetEncoding.CodeUnit>",
-                      "usr": "s:SP",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "DependentMember",
                           "printedName": "TargetEncoding.CodeUnit"
                         }
-                      ]
+                      ],
+                      "usr": "s:SP"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss11withCString9encodedAs_xq_m_xSPy8CodeUnitQy_GKXEtKs16_UnicodeEncodingR_r0_lF",
+          "moduleName": "Swift",
+          "genericSig": "<Result, TargetEncoding where TargetEncoding : _UnicodeEncoding>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss7Elementa",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -95372,22 +106953,21 @@
               "printedName": "Character",
               "usr": "s:SJ"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Ss7Elementa",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "IndexingIterator",
               "printedName": "IndexingIterator<Substring>",
-              "usr": "s:s16IndexingIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -95395,24 +106975,24 @@
                   "printedName": "Substring",
                   "usr": "s:Ss"
                 }
-              ]
+              ],
+              "usr": "s:s16IndexingIteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Ss8Iteratora",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DefaultIndices",
               "printedName": "DefaultIndices<Substring>",
-              "usr": "s:SI",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -95420,18 +107000,19 @@
                   "printedName": "Substring",
                   "usr": "s:Ss"
                 }
-              ]
+              ],
+              "usr": "s:SI"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Ss7Indicesa",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Ss9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -95443,10 +107024,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -95454,18 +107031,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:Ss12customMirrors0B0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -95477,10 +107058,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss12customMirrors0B0Vvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -95488,21 +107065,20 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss12customMirrors0B0Vvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss12customMirrors0B0Vvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:Ss11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -95514,10 +107090,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -95525,18 +107097,23 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss11descriptionSSvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss11descriptionSSvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Ss16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -95548,10 +107125,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -95559,21 +107132,20 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss16debugDescriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SsySsSScfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -95587,33 +107159,23 @@
               "printedName": "String",
               "usr": "s:SS"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SsySsSScfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "UTF8View",
           "printedName": "UTF8View",
-          "declKind": "Struct",
-          "usr": "s:Ss8UTF8ViewV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Index",
               "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss8UTF8ViewV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -95628,16 +107190,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Ss8UTF8ViewV5Indexa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "Indices",
               "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss8UTF8ViewV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -95648,7 +107209,6 @@
                       "kind": "TypeNominal",
                       "name": "DefaultIndices",
                       "printedName": "DefaultIndices<String.UTF8View>",
-                      "usr": "s:SI",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -95656,20 +107216,20 @@
                           "printedName": "String.UTF8View",
                           "usr": "s:SS8UTF8ViewV"
                         }
-                      ]
+                      ],
+                      "usr": "s:SI"
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Ss8UTF8ViewV7Indicesa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss8UTF8ViewV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -95684,16 +107244,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Ss8UTF8ViewV7Elementa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss8UTF8ViewV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -95701,19 +107260,15 @@
                   "printedName": "Substring.UTF8View",
                   "usr": "s:Ss8UTF8ViewV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Ss8UTF8ViewV11SubSequencea",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:Ss8UTF8ViewV10startIndexSS0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -95732,10 +107287,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss8UTF8ViewV10startIndexSS0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -95750,21 +107301,23 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss8UTF8ViewV10startIndexSS0D0Vvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss8UTF8ViewV10startIndexSS0D0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:Ss8UTF8ViewV8endIndexSS0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -95783,10 +107336,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss8UTF8ViewV8endIndexSS0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -95801,21 +107350,62 @@
                         }
                       ]
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss8UTF8ViewV8endIndexSS0D0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss8UTF8ViewV8endIndexSS0D0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Element",
+                  "printedName": "Substring.UTF8View.Element",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt8",
+                      "printedName": "UInt8",
+                      "usr": "s:s5UInt8V"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "Substring.UTF8View.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
                   ]
                 }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:Ss8UTF8ViewVys5UInt8VSS5IndexVcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:Ss8UTF8ViewV7indicesSIySSAAVGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -95826,7 +107416,6 @@
                       "kind": "TypeNominal",
                       "name": "DefaultIndices",
                       "printedName": "DefaultIndices<String.UTF8View>",
-                      "usr": "s:SI",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -95834,7 +107423,8 @@
                           "printedName": "String.UTF8View",
                           "usr": "s:SS8UTF8ViewV"
                         }
-                      ]
+                      ],
+                      "usr": "s:SI"
                     }
                   ]
                 },
@@ -95842,10 +107432,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss8UTF8ViewV7indicesSIySSAAVGvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -95856,7 +107442,6 @@
                           "kind": "TypeNominal",
                           "name": "DefaultIndices",
                           "printedName": "DefaultIndices<String.UTF8View>",
-                          "usr": "s:SI",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -95864,25 +107449,28 @@
                               "printedName": "String.UTF8View",
                               "usr": "s:SS8UTF8ViewV"
                             }
-                          ]
+                          ],
+                          "usr": "s:SI"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss8UTF8ViewV7indicesSIySSAAVGvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss8UTF8ViewV7indicesSIySSAAVGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:Ss8UTF8ViewV5index5afterSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -95910,19 +107498,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss8UTF8ViewV5index5afterSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "formIndex",
               "printedName": "formIndex(after:)",
-              "declKind": "Func",
-              "usr": "s:Ss8UTF8ViewV9formIndex5afterySS0D0Vz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -95942,19 +107529,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss8UTF8ViewV9formIndex5afterySS0D0Vz_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(_:offsetBy:)",
-              "declKind": "Func",
-              "usr": "s:Ss8UTF8ViewV5index_8offsetBySS5IndexVAF_SitF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -95988,25 +107574,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss8UTF8ViewV5index_8offsetBySS5IndexVAF_SitF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(_:offsetBy:limitedBy:)",
-              "declKind": "Func",
-              "usr": "s:Ss8UTF8ViewV5index_8offsetBy07limitedE0SS5IndexVSgAG_SiAGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Substring.UTF8View.Index?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -96021,7 +107605,8 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNameAlias",
@@ -96055,19 +107640,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss8UTF8ViewV5index_8offsetBy07limitedE0SS5IndexVSgAG_SiAGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "distance",
               "printedName": "distance(from:to:)",
-              "declKind": "Func",
-              "usr": "s:Ss8UTF8ViewV8distance4from2toSiSS5IndexV_AGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -96101,19 +107685,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss8UTF8ViewV8distance4from2toSiSS5IndexV_AGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:Ss8UTF8ViewV5index6beforeSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -96141,19 +107724,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss8UTF8ViewV5index6beforeSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "formIndex",
               "printedName": "formIndex(before:)",
-              "declKind": "Func",
-              "usr": "s:Ss8UTF8ViewV9formIndex6beforeySS0D0Vz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -96173,22 +107755,63 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss8UTF8ViewV9formIndex6beforeySS0D0Vz_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF8View",
+                  "printedName": "Substring.UTF8View",
+                  "usr": "s:Ss8UTF8ViewV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Substring.UTF8View.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Index",
+                      "printedName": "Substring.UTF8View.Index",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
+                      ]
+                    }
+                  ],
+                  "usr": "s:Sn"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:Ss8UTF8ViewVyABSnySS5IndexVGcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss8UTF8ViewV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "IndexingIterator",
                   "printedName": "IndexingIterator<Substring.UTF8View>",
-                  "usr": "s:s16IndexingIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -96196,23 +107819,32 @@
                       "printedName": "Substring.UTF8View",
                       "usr": "s:Ss8UTF8ViewV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s16IndexingIteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Ss8UTF8ViewV8Iteratora",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:Ss8UTF8ViewV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "utf8",
           "printedName": "utf8",
-          "declKind": "Var",
-          "usr": "s:Ss4utf8Ss8UTF8ViewVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -96224,10 +107856,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss4utf8Ss8UTF8ViewVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -96235,17 +107863,15 @@
                   "printedName": "Substring.UTF8View",
                   "usr": "s:Ss8UTF8ViewV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss4utf8Ss8UTF8ViewVvg",
+              "moduleName": "Swift"
             },
             {
               "kind": "Setter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss4utf8Ss8UTF8ViewVvs",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -96258,21 +107884,24 @@
                   "printedName": "Substring.UTF8View",
                   "usr": "s:Ss8UTF8ViewV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss4utf8Ss8UTF8ViewVvs",
+              "moduleName": "Swift",
+              "mutating": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss4utf8Ss8UTF8ViewVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SsyS2s8UTF8ViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -96286,33 +107915,23 @@
               "printedName": "Substring.UTF8View",
               "usr": "s:Ss8UTF8ViewV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SsyS2s8UTF8ViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "UTF16View",
           "printedName": "UTF16View",
-          "declKind": "Struct",
-          "usr": "s:Ss9UTF16ViewV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Index",
               "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss9UTF16ViewV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -96327,16 +107946,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Ss9UTF16ViewV5Indexa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "Indices",
               "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss9UTF16ViewV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -96344,16 +107962,15 @@
                   "printedName": "String.UTF16View.Indices",
                   "usr": "s:SS9UTF16ViewV7IndicesV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Ss9UTF16ViewV7Indicesa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss9UTF16ViewV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -96368,16 +107985,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Ss9UTF16ViewV7Elementa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss9UTF16ViewV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -96385,19 +108001,15 @@
                   "printedName": "Substring.UTF16View",
                   "usr": "s:Ss9UTF16ViewV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Ss9UTF16ViewV11SubSequencea",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:Ss9UTF16ViewV10startIndexSS0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -96416,10 +108028,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss9UTF16ViewV10startIndexSS0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -96434,21 +108042,23 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss9UTF16ViewV10startIndexSS0D0Vvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss9UTF16ViewV10startIndexSS0D0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:Ss9UTF16ViewV8endIndexSS0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -96467,10 +108077,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss9UTF16ViewV8endIndexSS0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -96485,21 +108091,62 @@
                         }
                       ]
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss9UTF16ViewV8endIndexSS0D0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss9UTF16ViewV8endIndexSS0D0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Element",
+                  "printedName": "Substring.UTF16View.Element",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UInt16",
+                      "printedName": "UInt16",
+                      "usr": "s:s6UInt16V"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "Substring.UTF16View.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
                   ]
                 }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:Ss9UTF16ViewVys6UInt16VSS5IndexVcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:Ss9UTF16ViewV7indicesSSAAV7IndicesVvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -96518,10 +108165,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss9UTF16ViewV7indicesSSAAV7IndicesVvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -96536,21 +108179,23 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss9UTF16ViewV7indicesSSAAV7IndicesVvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss9UTF16ViewV7indicesSSAAV7IndicesVvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:Ss9UTF16ViewV5index5afterSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -96578,19 +108223,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss9UTF16ViewV5index5afterSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "formIndex",
               "printedName": "formIndex(after:)",
-              "declKind": "Func",
-              "usr": "s:Ss9UTF16ViewV9formIndex5afterySS0D0Vz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -96610,19 +108254,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss9UTF16ViewV9formIndex5afterySS0D0Vz_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(_:offsetBy:)",
-              "declKind": "Func",
-              "usr": "s:Ss9UTF16ViewV5index_8offsetBySS5IndexVAF_SitF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -96656,25 +108299,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss9UTF16ViewV5index_8offsetBySS5IndexVAF_SitF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(_:offsetBy:limitedBy:)",
-              "declKind": "Func",
-              "usr": "s:Ss9UTF16ViewV5index_8offsetBy07limitedE0SS5IndexVSgAG_SiAGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Substring.UTF16View.Index?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -96689,7 +108330,8 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNameAlias",
@@ -96723,19 +108365,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss9UTF16ViewV5index_8offsetBy07limitedE0SS5IndexVSgAG_SiAGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "distance",
               "printedName": "distance(from:to:)",
-              "declKind": "Func",
-              "usr": "s:Ss9UTF16ViewV8distance4from2toSiSS5IndexV_AGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -96769,19 +108410,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss9UTF16ViewV8distance4from2toSiSS5IndexV_AGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:Ss9UTF16ViewV5index6beforeSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -96809,19 +108449,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss9UTF16ViewV5index6beforeSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "formIndex",
               "printedName": "formIndex(before:)",
-              "declKind": "Func",
-              "usr": "s:Ss9UTF16ViewV9formIndex6beforeySS0D0Vz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -96841,22 +108480,63 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss9UTF16ViewV9formIndex6beforeySS0D0Vz_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF16View",
+                  "printedName": "Substring.UTF16View",
+                  "usr": "s:Ss9UTF16ViewV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Substring.UTF16View.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Index",
+                      "printedName": "Substring.UTF16View.Index",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
+                      ]
+                    }
+                  ],
+                  "usr": "s:Sn"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:Ss9UTF16ViewVyABSnySS5IndexVGcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss9UTF16ViewV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "IndexingIterator",
                   "printedName": "IndexingIterator<Substring.UTF16View>",
-                  "usr": "s:s16IndexingIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -96864,23 +108544,32 @@
                       "printedName": "Substring.UTF16View",
                       "usr": "s:Ss9UTF16ViewV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s16IndexingIteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Ss9UTF16ViewV8Iteratora",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:Ss9UTF16ViewV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence"
           ]
         },
         {
           "kind": "Var",
           "name": "utf16",
           "printedName": "utf16",
-          "declKind": "Var",
-          "usr": "s:Ss5utf16Ss9UTF16ViewVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -96892,10 +108581,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss5utf16Ss9UTF16ViewVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -96903,17 +108588,15 @@
                   "printedName": "Substring.UTF16View",
                   "usr": "s:Ss9UTF16ViewV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss5utf16Ss9UTF16ViewVvg",
+              "moduleName": "Swift"
             },
             {
               "kind": "Setter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss5utf16Ss9UTF16ViewVvs",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -96926,21 +108609,24 @@
                   "printedName": "Substring.UTF16View",
                   "usr": "s:Ss9UTF16ViewV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss5utf16Ss9UTF16ViewVvs",
+              "moduleName": "Swift",
+              "mutating": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss5utf16Ss9UTF16ViewVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SsyS2s9UTF16ViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -96954,34 +108640,23 @@
               "printedName": "Substring.UTF16View",
               "usr": "s:Ss9UTF16ViewV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SsyS2s9UTF16ViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "UnicodeScalarView",
           "printedName": "UnicodeScalarView",
-          "declKind": "Struct",
-          "usr": "s:Ss17UnicodeScalarViewV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "BidirectionalCollection",
-            "Collection",
-            "Sequence",
-            "RangeReplaceableCollection"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "Index",
               "printedName": "Index",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss17UnicodeScalarViewV5Indexa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -96996,16 +108671,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Ss17UnicodeScalarViewV5Indexa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "Indices",
               "printedName": "Indices",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss17UnicodeScalarViewV7Indicesa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -97016,7 +108690,6 @@
                       "kind": "TypeNominal",
                       "name": "DefaultIndices",
                       "printedName": "DefaultIndices<String.UnicodeScalarView>",
-                      "usr": "s:SI",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -97024,20 +108697,20 @@
                           "printedName": "String.UnicodeScalarView",
                           "usr": "s:SS17UnicodeScalarViewV"
                         }
-                      ]
+                      ],
+                      "usr": "s:SI"
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Ss17UnicodeScalarViewV7Indicesa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss17UnicodeScalarViewV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -97052,16 +108725,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Ss17UnicodeScalarViewV7Elementa",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss17UnicodeScalarViewV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -97069,19 +108741,15 @@
                   "printedName": "Substring.UnicodeScalarView",
                   "usr": "s:Ss17UnicodeScalarViewV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Ss17UnicodeScalarViewV11SubSequencea",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "startIndex",
               "printedName": "startIndex",
-              "declKind": "Var",
-              "usr": "s:Ss17UnicodeScalarViewV10startIndexSS0E0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -97100,10 +108768,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss17UnicodeScalarViewV10startIndexSS0E0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -97118,21 +108782,23 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss17UnicodeScalarViewV10startIndexSS0E0Vvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss17UnicodeScalarViewV10startIndexSS0E0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "endIndex",
               "printedName": "endIndex",
-              "declKind": "Var",
-              "usr": "s:Ss17UnicodeScalarViewV8endIndexSS0E0Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -97151,10 +108817,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss17UnicodeScalarViewV8endIndexSS0E0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -97169,21 +108831,62 @@
                         }
                       ]
                     }
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss17UnicodeScalarViewV8endIndexSS0E0Vvg",
+                  "moduleName": "Swift"
+                }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss17UnicodeScalarViewV8endIndexSS0E0Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Element",
+                  "printedName": "Substring.UnicodeScalarView.Element",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Scalar",
+                      "printedName": "Unicode.Scalar",
+                      "usr": "s:s7UnicodeO6ScalarV"
+                    }
+                  ]
+                },
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "Substring.UnicodeScalarView.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
                   ]
                 }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:Ss17UnicodeScalarViewVys0A0O0B0VSS5IndexVcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "indices",
               "printedName": "indices",
-              "declKind": "Var",
-              "usr": "s:Ss17UnicodeScalarViewV7indicesSIySSAAVGvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -97194,7 +108897,6 @@
                       "kind": "TypeNominal",
                       "name": "DefaultIndices",
                       "printedName": "DefaultIndices<String.UnicodeScalarView>",
-                      "usr": "s:SI",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -97202,7 +108904,8 @@
                           "printedName": "String.UnicodeScalarView",
                           "usr": "s:SS17UnicodeScalarViewV"
                         }
-                      ]
+                      ],
+                      "usr": "s:SI"
                     }
                   ]
                 },
@@ -97210,10 +108913,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:Ss17UnicodeScalarViewV7indicesSIySSAAVGvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -97224,7 +108923,6 @@
                           "kind": "TypeNominal",
                           "name": "DefaultIndices",
                           "printedName": "DefaultIndices<String.UnicodeScalarView>",
-                          "usr": "s:SI",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -97232,25 +108930,28 @@
                               "printedName": "String.UnicodeScalarView",
                               "usr": "s:SS17UnicodeScalarViewV"
                             }
-                          ]
+                          ],
+                          "usr": "s:SI"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:Ss17UnicodeScalarViewV7indicesSIySSAAVGvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:Ss17UnicodeScalarViewV7indicesSIySSAAVGvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(after:)",
-              "declKind": "Func",
-              "usr": "s:Ss17UnicodeScalarViewV5index5afterSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -97278,19 +108979,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss17UnicodeScalarViewV5index5afterSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "formIndex",
               "printedName": "formIndex(after:)",
-              "declKind": "Func",
-              "usr": "s:Ss17UnicodeScalarViewV9formIndex5afterySS0E0Vz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -97310,19 +109010,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss17UnicodeScalarViewV9formIndex5afterySS0E0Vz_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(_:offsetBy:)",
-              "declKind": "Func",
-              "usr": "s:Ss17UnicodeScalarViewV5index_8offsetBySS5IndexVAF_SitF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -97356,25 +109055,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss17UnicodeScalarViewV5index_8offsetBySS5IndexVAF_SitF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(_:offsetBy:limitedBy:)",
-              "declKind": "Func",
-              "usr": "s:Ss17UnicodeScalarViewV5index_8offsetBy07limitedF0SS5IndexVSgAG_SiAGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Substring.UnicodeScalarView.Index?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -97389,7 +109086,8 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNameAlias",
@@ -97423,19 +109121,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss17UnicodeScalarViewV5index_8offsetBy07limitedF0SS5IndexVSgAG_SiAGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "distance",
               "printedName": "distance(from:to:)",
-              "declKind": "Func",
-              "usr": "s:Ss17UnicodeScalarViewV8distance4from2toSiSS5IndexV_AGtF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -97469,19 +109166,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss17UnicodeScalarViewV8distance4from2toSiSS5IndexV_AGtF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "index",
               "printedName": "index(before:)",
-              "declKind": "Func",
-              "usr": "s:Ss17UnicodeScalarViewV5index6beforeSS5IndexVAF_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -97509,19 +109205,18 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss17UnicodeScalarViewV5index6beforeSS5IndexVAF_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "formIndex",
               "printedName": "formIndex(before:)",
-              "declKind": "Func",
-              "usr": "s:Ss17UnicodeScalarViewV9formIndex6beforeySS0E0Vz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -97541,22 +109236,63 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss17UnicodeScalarViewV9formIndex6beforeySS0E0Vz_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Subscript",
+              "name": "subscript",
+              "printedName": "subscript(_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnicodeScalarView",
+                  "printedName": "Substring.UnicodeScalarView",
+                  "usr": "s:Ss17UnicodeScalarViewV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Range",
+                  "printedName": "Range<Substring.UnicodeScalarView.Index>",
+                  "children": [
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "Index",
+                      "printedName": "Substring.UnicodeScalarView.Index",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "Index",
+                          "printedName": "String.Index",
+                          "usr": "s:SS5IndexV"
+                        }
+                      ]
+                    }
+                  ],
+                  "usr": "s:Sn"
+                }
+              ],
+              "declKind": "Subscript",
+              "usr": "s:Ss17UnicodeScalarViewVyABSnySS5IndexVGcip",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:Ss17UnicodeScalarViewV8Iteratora",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "IndexingIterator",
                   "printedName": "IndexingIterator<Substring.UnicodeScalarView>",
-                  "usr": "s:s16IndexingIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -97564,21 +109300,19 @@
                       "printedName": "Substring.UnicodeScalarView",
                       "usr": "s:Ss17UnicodeScalarViewV"
                     }
-                  ]
+                  ],
+                  "usr": "s:s16IndexingIteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:Ss17UnicodeScalarViewV8Iteratora",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init()",
-              "declKind": "Constructor",
-              "usr": "s:Ss17UnicodeScalarViewVABycfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -97586,21 +109320,18 @@
                   "printedName": "Substring.UnicodeScalarView",
                   "usr": "s:Ss17UnicodeScalarViewV"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:Ss17UnicodeScalarViewVABycfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "replaceSubrange",
               "printedName": "replaceSubrange(_:with:)",
-              "declKind": "Func",
-              "usr": "s:Ss17UnicodeScalarViewV15replaceSubrange_4withySnySS5IndexVG_xtSlRzs0A0O0B0V7ElementRtzlF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<C where C : Collection, C.Element == Substring.UnicodeScalarView.Element>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -97611,7 +109342,6 @@
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<Substring.UnicodeScalarView.Index>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -97626,28 +109356,42 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 },
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "C"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:Ss17UnicodeScalarViewV15replaceSubrange_4withySnySS5IndexVG_xtSlRzs0A0O0B0V7ElementRtzlF",
+              "moduleName": "Swift",
+              "genericSig": "<C where C : Collection, C.Element == Substring.UnicodeScalarView.Element>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:Ss17UnicodeScalarViewV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "BidirectionalCollection",
+            "Collection",
+            "Sequence",
+            "RangeReplaceableCollection"
           ]
         },
         {
           "kind": "Var",
           "name": "unicodeScalars",
           "printedName": "unicodeScalars",
-          "declKind": "Var",
-          "usr": "s:Ss14unicodeScalarsSs17UnicodeScalarViewVvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -97659,10 +109403,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss14unicodeScalarsSs17UnicodeScalarViewVvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -97670,17 +109410,15 @@
                   "printedName": "Substring.UnicodeScalarView",
                   "usr": "s:Ss17UnicodeScalarViewV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss14unicodeScalarsSs17UnicodeScalarViewVvg",
+              "moduleName": "Swift"
             },
             {
               "kind": "Setter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss14unicodeScalarsSs17UnicodeScalarViewVvs",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -97693,21 +109431,24 @@
                   "printedName": "Substring.UnicodeScalarView",
                   "usr": "s:Ss17UnicodeScalarViewV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss14unicodeScalarsSs17UnicodeScalarViewVvs",
+              "moduleName": "Swift",
+              "mutating": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss14unicodeScalarsSs17UnicodeScalarViewVvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SsyS2s17UnicodeScalarViewVcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -97721,20 +109462,18 @@
               "printedName": "Substring.UnicodeScalarView",
               "usr": "s:Ss17UnicodeScalarViewV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SsyS2s17UnicodeScalarViewVcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SsySsxcSTRzSJ7ElementRtzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : Sequence, S.Element == Character>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -97747,21 +109486,19 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SsySsxcSTRzSJ7ElementRtzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<S where S : Sequence, S.Element == Character>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "append",
           "printedName": "append(contentsOf:)",
-          "declKind": "Func",
-          "usr": "s:Ss6append10contentsOfyx_tSTRzSJ7ElementRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : Sequence, S.Element == Character>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -97773,19 +109510,20 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss6append10contentsOfyx_tSTRzSJ7ElementRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<S where S : Sequence, S.Element == Character>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "lowercased",
           "printedName": "lowercased()",
-          "declKind": "Func",
-          "usr": "s:Ss10lowercasedSSyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -97793,19 +109531,18 @@
               "printedName": "String",
               "usr": "s:SS"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss10lowercasedSSyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "uppercased",
           "printedName": "uppercased()",
-          "declKind": "Func",
-          "usr": "s:Ss10uppercasedSSyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -97813,21 +109550,18 @@
               "printedName": "String",
               "usr": "s:SS"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss10uppercasedSSyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:Ss6filterySSSbSJKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -97839,9 +109573,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Substring.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -97853,7 +109584,6 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(Substring.Element)",
-                  "usr": "s:SJ",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -97868,24 +109598,28 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:SJ"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss6filterySSSbSJKXEKF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "write",
           "printedName": "write(_:)",
-          "declKind": "Func",
-          "usr": "s:Ss5writeyySSF",
-          "location": "",
-          "moduleName": "Swift",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -97898,20 +109632,19 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss5writeyySSF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "write",
           "printedName": "write(to:)",
-          "declKind": "Func",
-          "usr": "s:Ss5write2toyxz_ts16TextOutputStreamRzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Target where Target : TextOutputStream>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -97923,19 +109656,19 @@
               "name": "GenericTypeParam",
               "printedName": "Target"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss5write2toyxz_ts16TextOutputStreamRzlF",
+          "moduleName": "Swift",
+          "genericSig": "<Target where Target : TextOutputStream>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(unicodeScalarLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Ss20unicodeScalarLiteralSsSS_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -97949,16 +109682,18 @@
               "printedName": "String",
               "usr": "s:SS"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Ss20unicodeScalarLiteralSsSS_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "UnicodeScalarLiteralType",
           "printedName": "UnicodeScalarLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss24UnicodeScalarLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -97966,19 +109701,16 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Ss24UnicodeScalarLiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(extendedGraphemeClusterLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Ss30extendedGraphemeClusterLiteralSsSS_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -97992,16 +109724,18 @@
               "printedName": "String",
               "usr": "s:SS"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Ss30extendedGraphemeClusterLiteralSsSS_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "ExtendedGraphemeClusterLiteralType",
           "printedName": "ExtendedGraphemeClusterLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss34ExtendedGraphemeClusterLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -98009,19 +109743,16 @@
               "printedName": "String",
               "usr": "s:SS"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Ss34ExtendedGraphemeClusterLiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(stringLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:Ss13stringLiteralSsSS_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -98035,16 +109766,18 @@
               "printedName": "String",
               "usr": "s:SS"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Ss13stringLiteralSsSS_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "StringLiteralType",
           "printedName": "StringLiteralType",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss17StringLiteralTypea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -98052,20 +109785,57 @@
               "printedName": "String",
               "usr": "s:SS"
             }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Ss17StringLiteralTypea",
+          "moduleName": "Swift",
+          "implicit": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Substring",
+              "printedName": "Substring",
+              "usr": "s:Ss"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Substring.Index>",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "Substring.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Index",
+                      "printedName": "String.Index",
+                      "usr": "s:SS5IndexV"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SsySsSnySS5IndexVGcip",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Available",
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "CharacterView",
           "printedName": "CharacterView",
-          "declKind": "TypeAlias",
-          "usr": "s:Ss13CharacterViewa",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -98073,20 +109843,19 @@
               "printedName": "Substring",
               "usr": "s:Ss"
             }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Ss13CharacterViewa",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Var",
           "name": "characters",
           "printedName": "characters",
-          "declKind": "Var",
-          "usr": "s:Ss10charactersSsvp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -98098,10 +109867,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss10charactersSsvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -98109,17 +109874,15 @@
                   "printedName": "Substring",
                   "usr": "s:Ss"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss10charactersSsvg",
+              "moduleName": "Swift"
             },
             {
               "kind": "Setter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss10charactersSsvs",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -98132,24 +109895,25 @@
                   "printedName": "Substring",
                   "usr": "s:Ss"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss10charactersSsvs",
+              "moduleName": "Swift",
+              "mutating": true
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss10charactersSsvp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "withMutableCharacters",
           "printedName": "withMutableCharacters(_:)",
-          "declKind": "Func",
-          "usr": "s:Ss21withMutableCharactersyxxSszXElF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<R>",
-          "deprecated": true,
-          "mutating": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -98160,9 +109924,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(inout Substring) -> R",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -98181,22 +109942,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Ss21withMutableCharactersyxxSszXElF",
+          "moduleName": "Swift",
+          "genericSig": "<R>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
+          ],
+          "mutating": true
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:Ss25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -98208,10 +109973,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Ss25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -98219,51 +109980,71 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Ss25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Ss25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:Ss",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "StringProtocol",
+        "BidirectionalCollection",
+        "Hashable",
+        "Comparable",
+        "Collection",
+        "Sequence",
+        "Equatable",
+        "_SwiftStringView",
+        "CustomReflectable",
+        "CustomStringConvertible",
+        "CustomDebugStringConvertible",
+        "LosslessStringConvertible",
+        "RangeReplaceableCollection",
+        "TextOutputStream",
+        "TextOutputStreamable",
+        "ExpressibleByUnicodeScalarLiteral",
+        "ExpressibleByExtendedGraphemeClusterLiteral",
+        "ExpressibleByStringLiteral",
+        "_CustomPlaygroundQuickLookable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Unmanaged",
       "printedName": "Unmanaged",
-      "declKind": "Struct",
-      "usr": "s:s9UnmanagedV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Instance where Instance : AnyObject>",
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Function",
           "name": "fromOpaque",
           "printedName": "fromOpaque(_:)",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV10fromOpaqueyAByxGSVFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Unmanaged",
               "printedName": "Unmanaged<Instance>",
-              "usr": "s:s9UnmanagedV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Instance"
                 }
-              ]
+              ],
+              "usr": "s:s9UnmanagedV"
             },
             {
               "kind": "TypeNominal",
@@ -98271,20 +110052,20 @@
               "printedName": "UnsafeRawPointer",
               "usr": "s:SV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV10fromOpaqueyAByxGSVFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Instance where Instance : AnyObject>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "toOpaque",
           "printedName": "toOpaque()",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV8toOpaqueSvyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -98292,224 +110073,210 @@
               "printedName": "UnsafeMutableRawPointer",
               "usr": "s:Sv"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV8toOpaqueSvyF",
+          "moduleName": "Swift",
+          "genericSig": "<Instance where Instance : AnyObject>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "passRetained",
           "printedName": "passRetained(_:)",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV12passRetainedyAByxGxFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Unmanaged",
               "printedName": "Unmanaged<Instance>",
-              "usr": "s:s9UnmanagedV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Instance"
                 }
-              ]
+              ],
+              "usr": "s:s9UnmanagedV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Instance"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV12passRetainedyAByxGxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Instance where Instance : AnyObject>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "passUnretained",
           "printedName": "passUnretained(_:)",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV14passUnretainedyAByxGxFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "static": true,
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Unmanaged",
               "printedName": "Unmanaged<Instance>",
-              "usr": "s:s9UnmanagedV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Instance"
                 }
-              ]
+              ],
+              "usr": "s:s9UnmanagedV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Instance"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV14passUnretainedyAByxGxFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Instance where Instance : AnyObject>",
+          "static": true,
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "takeUnretainedValue",
           "printedName": "takeUnretainedValue()",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV19takeUnretainedValuexyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Instance"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV19takeUnretainedValuexyF",
+          "moduleName": "Swift",
+          "genericSig": "<Instance where Instance : AnyObject>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "takeRetainedValue",
           "printedName": "takeRetainedValue()",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV17takeRetainedValuexyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Instance"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV17takeRetainedValuexyF",
+          "moduleName": "Swift",
+          "genericSig": "<Instance where Instance : AnyObject>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "retain",
           "printedName": "retain()",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV6retainAByxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Unmanaged",
               "printedName": "Unmanaged<Instance>",
-              "usr": "s:s9UnmanagedV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Instance"
                 }
-              ]
+              ],
+              "usr": "s:s9UnmanagedV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV6retainAByxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Instance where Instance : AnyObject>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "release",
           "printedName": "release()",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV7releaseyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV7releaseyyF",
+          "moduleName": "Swift",
+          "genericSig": "<Instance where Instance : AnyObject>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "autorelease",
           "printedName": "autorelease()",
-          "declKind": "Func",
-          "usr": "s:s9UnmanagedV11autoreleaseAByxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Instance where Instance : AnyObject>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Unmanaged",
               "printedName": "Unmanaged<Instance>",
-              "usr": "s:s9UnmanagedV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Instance"
                 }
-              ]
+              ],
+              "usr": "s:s9UnmanagedV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s9UnmanagedV11autoreleaseAByxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Instance where Instance : AnyObject>",
+          "declAttributes": [
+            "Transparent"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s9UnmanagedV",
+      "moduleName": "Swift",
+      "genericSig": "<Instance where Instance : AnyObject>",
+      "declAttributes": [
+        "FixedLayout"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnsafeMutableBufferPointer",
       "printedName": "UnsafeMutableBufferPointer",
-      "declKind": "Struct",
-      "usr": "s:Sr",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "_HasContiguousBytes",
-        "Sequence",
-        "MutableCollection",
-        "RandomAccessCollection",
-        "Collection",
-        "BidirectionalCollection",
-        "CustomDebugStringConvertible"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:Sr5countSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -98521,14 +110288,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sr5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -98536,19 +110295,28 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sr5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sr5countSivp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:Sr8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -98556,20 +110324,16 @@
               "printedName": "UnsafeBufferPointer<Element>.Iterator",
               "usr": "s:SR8IteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sr8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:Sr12makeIteratorSR0B0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -98584,17 +110348,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr12makeIteratorSR0B0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:Sr5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -98602,23 +110368,21 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sr5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:Sr7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Int>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -98626,21 +110390,19 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sr7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:Sr10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -98652,11 +110414,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sr10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -98664,21 +110421,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sr10startIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sr10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:Sr8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -98690,11 +110450,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sr8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -98702,22 +110457,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sr8endIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sr8endIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:Sr5index5afterS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -98731,20 +110488,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr5index5afterS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:Sr9formIndex5afterySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -98757,20 +110513,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr9formIndex5afterySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:Sr5index6beforeS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -98784,20 +110539,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr5index6beforeS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:Sr9formIndex6beforeySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -98810,20 +110564,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr9formIndex6beforeySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:Sr5index_8offsetByS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -98843,26 +110596,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr5index_8offsetByS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:Sr5index_8offsetBy07limitedC0SiSgSi_S2itF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -98870,7 +110621,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -98890,20 +110642,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr5index_8offsetBy07limitedC0SiSgSi_S2itF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:Sr8distance4from2toS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -98923,19 +110674,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr8distance4from2toS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:Sr7indicesSnySiGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -98946,7 +110697,6 @@
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<Int>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -98954,7 +110704,8 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
               ]
             },
@@ -98962,11 +110713,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sr7indicesSnySiGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -98977,7 +110723,6 @@
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -98985,26 +110730,105 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sr7indicesSnySiGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sr7indicesSnySiGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "Function",
-          "name": "swapAt",
-          "printedName": "swapAt(_:_:)",
-          "declKind": "Func",
-          "usr": "s:Sr6swapAtyySi_SitF",
-          "location": "",
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SryxSicip",
           "moduleName": "Swift",
           "genericSig": "<Element>",
           "declAttributes": [
             "Inlinable"
           ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<UnsafeMutableBufferPointer<Element>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeMutableBufferPointer",
+                  "printedName": "UnsafeMutableBufferPointer<Element>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Element"
+                    }
+                  ],
+                  "usr": "s:Sr"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Srys5SliceVySryxGGSnySiGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Function",
+          "name": "swapAt",
+          "printedName": "swapAt(_:_:)",
           "children": [
             {
               "kind": "TypeNominal",
@@ -99023,104 +110847,103 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr6swapAtyySi_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:Sr7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sr7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:Sr11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<UnsafeMutableBufferPointer<Element>>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafeMutableBufferPointer",
                   "printedName": "UnsafeMutableBufferPointer<Element>",
-                  "usr": "s:Sr",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sr"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sr11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(start:count:)",
-          "declKind": "Constructor",
-          "usr": "s:Sr5start5countSryxGSpyxGSg_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutableBufferPointer",
               "printedName": "UnsafeMutableBufferPointer<Element>",
-              "usr": "s:Sr",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sr"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeMutablePointer<Element>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafeMutablePointer",
                   "printedName": "UnsafeMutablePointer<Element>",
-                  "usr": "s:Sp",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -99128,137 +110951,131 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sr5start5countSryxGSpyxGSg_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(mutating:)",
-          "declKind": "Constructor",
-          "usr": "s:Sr8mutatingSryxGSRyxG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutableBufferPointer",
               "printedName": "UnsafeMutableBufferPointer<Element>",
-              "usr": "s:Sr",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sr"
             },
             {
               "kind": "TypeNominal",
               "name": "UnsafeBufferPointer",
               "printedName": "UnsafeBufferPointer<Element>",
-              "usr": "s:SR",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:SR"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sr8mutatingSryxGSRyxG_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(rebasing:)",
-          "declKind": "Constructor",
-          "usr": "s:Sr8rebasingSryxGs5SliceVyABG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutableBufferPointer",
               "printedName": "UnsafeMutableBufferPointer<Element>",
-              "usr": "s:Sr",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sr"
             },
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<UnsafeMutableBufferPointer<Element>>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafeMutableBufferPointer",
                   "printedName": "UnsafeMutableBufferPointer<Element>",
-                  "usr": "s:Sr",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sr"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sr8rebasingSryxGs5SliceVyABG_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "deallocate",
           "printedName": "deallocate()",
-          "declKind": "Func",
-          "usr": "s:Sr10deallocateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr10deallocateyyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "allocate",
           "printedName": "allocate(capacity:)",
-          "declKind": "Func",
-          "usr": "s:Sr8allocate8capacitySryxGSi_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutableBufferPointer",
               "printedName": "UnsafeMutableBufferPointer<UnsafeMutableBufferPointer<Element>.Element>",
-              "usr": "s:Sr",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -99272,7 +111089,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sr"
             },
             {
               "kind": "TypeNominal",
@@ -99280,20 +111098,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr8allocate8capacitySryxGSi_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "initialize",
           "printedName": "initialize(repeating:)",
-          "declKind": "Func",
-          "usr": "s:Sr10initialize9repeatingyx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -99312,20 +111130,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr10initialize9repeatingyx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "assign",
           "printedName": "assign(repeating:)",
-          "declKind": "Func",
-          "usr": "s:Sr6assign9repeatingyx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -99344,22 +111161,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr6assign9repeatingyx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "withMemoryRebound",
           "printedName": "withMemoryRebound(to:_:)",
-          "declKind": "Func",
-          "usr": "s:Sr17withMemoryRebound2to_qd_0_qd__m_qd_0_Sryqd__GKXEtKr0_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, T, Result>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -99382,9 +111196,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafeMutableBufferPointer<T>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -99395,103 +111206,109 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafeMutableBufferPointer<T>)",
-                  "usr": "s:Sr",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafeMutableBufferPointer",
                       "printedName": "UnsafeMutableBufferPointer<T>",
-                      "usr": "s:Sr",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
                           "printedName": "T"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sr"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sr"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr17withMemoryRebound2to_qd_0_qd__m_qd_0_Sryqd__GKXEtKr0_lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, T, Result>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Var",
           "name": "baseAddress",
           "printedName": "baseAddress",
-          "declKind": "Var",
-          "usr": "s:Sr11baseAddressSpyxGSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeMutablePointer<Element>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafeMutablePointer",
                   "printedName": "UnsafeMutablePointer<Element>",
-                  "usr": "s:Sp",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sr11baseAddressSpyxGSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "UnsafeMutablePointer<Element>?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafeMutablePointer",
                       "printedName": "UnsafeMutablePointer<Element>",
-                      "usr": "s:Sp",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
                           "printedName": "Element"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sp"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sr11baseAddressSpyxGSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sr11baseAddressSpyxGSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Sr16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -99503,11 +111320,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sr16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -99515,22 +111327,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sr16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sr16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "initialize",
           "printedName": "initialize(from:)",
-          "declKind": "Func",
-          "usr": "s:Sr10initialize4from8IteratorQyd___Sitqd___t7ElementQyd__RszSTRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -99562,39 +111373,42 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sr10initialize4from8IteratorQyd___Sitqd___t7ElementQyd__RszSTRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:Sr",
+      "moduleName": "Swift",
+      "genericSig": "<Element>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "_HasContiguousBytes",
+        "Sequence",
+        "MutableCollection",
+        "RandomAccessCollection",
+        "Collection",
+        "BidirectionalCollection",
+        "CustomDebugStringConvertible"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnsafeBufferPointer",
       "printedName": "UnsafeBufferPointer",
-      "declKind": "Struct",
-      "usr": "s:SR",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "_HasContiguousBytes",
-        "Sequence",
-        "Collection",
-        "RandomAccessCollection",
-        "BidirectionalCollection",
-        "CustomDebugStringConvertible"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:SR5countSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -99606,14 +111420,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SR5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -99621,86 +111427,90 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SR5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SR5countSivp",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1,
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:SR8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "conformingProtocols": [
-            "IteratorProtocol"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:SR8IteratorV4nextxSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:SR8IteratorV4nextxSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<Element>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:SR8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SR8IteratorV7Elementa",
+              "moduleName": "Swift",
+              "genericSig": "<Element>",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SR8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:SR12makeIteratorSR0B0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -99708,17 +111518,19 @@
               "printedName": "UnsafeBufferPointer<Element>.Iterator",
               "usr": "s:SR8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR12makeIteratorSR0B0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:SR5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -99726,23 +111538,21 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SR5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:SR7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Int>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -99750,21 +111560,19 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SR7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:SR10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -99776,11 +111584,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SR10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -99788,21 +111591,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SR10startIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SR10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:SR8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -99814,11 +111620,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SR8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -99826,22 +111627,24 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SR8endIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SR8endIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:SR5index5afterS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -99855,20 +111658,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR5index5afterS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:SR9formIndex5afterySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -99881,20 +111683,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR9formIndex5afterySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:SR5index6beforeS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -99908,20 +111709,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR5index6beforeS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:SR9formIndex6beforeySiz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -99934,20 +111734,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR9formIndex6beforeySiz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:SR5index_8offsetByS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -99967,26 +111766,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR5index_8offsetByS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:SR5index_8offsetBy07limitedC0SiSgSi_S2itF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Int?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -99994,7 +111791,8 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -100014,20 +111812,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR5index_8offsetBy07limitedC0SiSgSi_S2itF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:SR8distance4from2toS2i_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -100047,19 +111844,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR8distance4from2toS2i_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:SR7indicesSnySiGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -100070,7 +111867,6 @@
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<Int>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -100078,7 +111874,8 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
               ]
             },
@@ -100086,11 +111883,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SR7indicesSnySiGvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -100101,7 +111893,6 @@
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -100109,110 +111900,34 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SR7indicesSnySiGvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SR7indicesSnySiGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:SR7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:SR11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<UnsafeBufferPointer<Element>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafeBufferPointer",
-                  "printedName": "UnsafeBufferPointer<Element>",
-                  "usr": "s:SR",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(start:count:)",
-          "declKind": "Constructor",
-          "usr": "s:SR5start5countSRyxGSPyxGSg_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "UnsafeBufferPointer",
-              "printedName": "UnsafeBufferPointer<Element>",
-              "usr": "s:SR",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Optional",
-              "printedName": "UnsafePointer<Element>?",
-              "usr": "s:Sq",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafePointer",
-                  "printedName": "UnsafePointer<Element>",
-                  "usr": "s:SP",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Element"
-                    }
-                  ]
-                }
-              ]
             },
             {
               "kind": "TypeNominal",
@@ -100220,181 +111935,327 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SRyxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<UnsafeBufferPointer<Element>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeBufferPointer",
+                  "printedName": "UnsafeBufferPointer<Element>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Element"
+                    }
+                  ],
+                  "usr": "s:SR"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SRys5SliceVySRyxGGSnySiGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "Element",
+          "printedName": "Element",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Element"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SR7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
+        },
+        {
+          "kind": "TypeAlias",
+          "name": "SubSequence",
+          "printedName": "SubSequence",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Slice",
+              "printedName": "Slice<UnsafeBufferPointer<Element>>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeBufferPointer",
+                  "printedName": "UnsafeBufferPointer<Element>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Element"
+                    }
+                  ],
+                  "usr": "s:SR"
+                }
+              ],
+              "usr": "s:s5SliceV"
+            }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SR11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(start:count:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "UnsafeBufferPointer",
+              "printedName": "UnsafeBufferPointer<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:SR"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Optional",
+              "printedName": "UnsafePointer<Element>?",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafePointer",
+                  "printedName": "UnsafePointer<Element>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "Element"
+                    }
+                  ],
+                  "usr": "s:SP"
+                }
+              ],
+              "usr": "s:Sq"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SR5start5countSRyxGSPyxGSg_Sitcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SRySRyxGSryxGcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeBufferPointer",
               "printedName": "UnsafeBufferPointer<Element>",
-              "usr": "s:SR",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:SR"
             },
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutableBufferPointer",
               "printedName": "UnsafeMutableBufferPointer<Element>",
-              "usr": "s:Sr",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sr"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SRySRyxGSryxGcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(rebasing:)",
-          "declKind": "Constructor",
-          "usr": "s:SR8rebasingSRyxGs5SliceVyABG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeBufferPointer",
               "printedName": "UnsafeBufferPointer<Element>",
-              "usr": "s:SR",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:SR"
             },
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<UnsafeBufferPointer<Element>>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafeBufferPointer",
                   "printedName": "UnsafeBufferPointer<Element>",
-                  "usr": "s:SR",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:SR"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SR8rebasingSRyxGs5SliceVyABG_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(rebasing:)",
-          "declKind": "Constructor",
-          "usr": "s:SR8rebasingSRyxGs5SliceVySryxGG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeBufferPointer",
               "printedName": "UnsafeBufferPointer<Element>",
-              "usr": "s:SR",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:SR"
             },
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<UnsafeMutableBufferPointer<Element>>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafeMutableBufferPointer",
                   "printedName": "UnsafeMutableBufferPointer<Element>",
-                  "usr": "s:Sr",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sr"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SR8rebasingSRyxGs5SliceVySryxGG_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "deallocate",
           "printedName": "deallocate()",
-          "declKind": "Func",
-          "usr": "s:SR10deallocateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SR10deallocateyyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "withMemoryRebound",
           "printedName": "withMemoryRebound(to:_:)",
-          "declKind": "Func",
-          "usr": "s:SR17withMemoryRebound2to_qd_0_qd__m_qd_0_SRyqd__GKXEtKr0_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, T, Result>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -100417,9 +112278,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafeBufferPointer<T>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -100430,103 +112288,109 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafeBufferPointer<T>)",
-                  "usr": "s:SR",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafeBufferPointer",
                       "printedName": "UnsafeBufferPointer<T>",
-                      "usr": "s:SR",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
                           "printedName": "T"
                         }
-                      ]
+                      ],
+                      "usr": "s:SR"
                     }
-                  ]
+                  ],
+                  "usr": "s:SR"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:SR17withMemoryRebound2to_qd_0_qd__m_qd_0_SRyqd__GKXEtKr0_lF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, T, Result>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Var",
           "name": "baseAddress",
           "printedName": "baseAddress",
-          "declKind": "Var",
-          "usr": "s:SR11baseAddressSPyxGSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafePointer<Element>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafePointer",
                   "printedName": "UnsafePointer<Element>",
-                  "usr": "s:SP",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SR11baseAddressSPyxGSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "UnsafePointer<Element>?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafePointer",
                       "printedName": "UnsafePointer<Element>",
-                      "usr": "s:SP",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
                           "printedName": "Element"
                         }
-                      ]
+                      ],
+                      "usr": "s:SP"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SR11baseAddressSPyxGSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SR11baseAddressSPyxGSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:SR16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -100538,11 +112402,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SR16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -100550,40 +112409,43 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SR16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SR16debugDescriptionSSvp",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:SR",
+      "moduleName": "Swift",
+      "genericSig": "<Element>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "_HasContiguousBytes",
+        "Sequence",
+        "Collection",
+        "RandomAccessCollection",
+        "BidirectionalCollection",
+        "CustomDebugStringConvertible"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnsafeMutableRawBufferPointer",
       "printedName": "UnsafeMutableRawBufferPointer",
-      "declKind": "Struct",
-      "usr": "s:Sw",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Sequence",
-        "MutableCollection",
-        "Collection",
-        "RandomAccessCollection",
-        "BidirectionalCollection",
-        "CustomDebugStringConvertible"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:Sw8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -100591,22 +112453,20 @@
               "printedName": "UnsafeRawBufferPointer.Iterator",
               "usr": "s:SW8IteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sw8Iteratora",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:Sw11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<UnsafeMutableRawBufferPointer>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -100614,21 +112474,18 @@
                   "printedName": "UnsafeMutableRawBufferPointer",
                   "usr": "s:Sw"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sw11SubSequencea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:Sw12makeIteratorSW0B0VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -100643,16 +112500,18 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw12makeIteratorSW0B0VyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:Sw7Elementa",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -100660,16 +112519,15 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sw7Elementa",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:Sw5Indexa",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -100677,22 +112535,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sw5Indexa",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:Sw7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Int>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -100700,21 +112556,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sw7Indicesa",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:Sw10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -100733,10 +112586,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sw10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -100751,21 +112600,23 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sw10startIndexSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sw10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:Sw8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -100784,10 +112635,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sw8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -100802,21 +112649,23 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sw8endIndexSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sw8endIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:Sw7indicesSnySiGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -100827,7 +112676,6 @@
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<Int>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -100835,7 +112683,8 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
               ]
             },
@@ -100843,10 +112692,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sw7indicesSnySiGvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -100857,7 +112702,6 @@
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -100865,25 +112709,110 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sw7indicesSnySiGvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sw7indicesSnySiGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Element",
+              "printedName": "UnsafeMutableRawBufferPointer.Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt8",
+                  "printedName": "UInt8",
+                  "usr": "s:s5UInt8V"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Swys5UInt8VSicip",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "SubSequence",
+              "printedName": "UnsafeMutableRawBufferPointer.SubSequence",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Slice",
+                  "printedName": "Slice<UnsafeMutableRawBufferPointer>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafeMutableRawBufferPointer",
+                      "printedName": "UnsafeMutableRawBufferPointer",
+                      "usr": "s:Sw"
+                    }
+                  ],
+                  "usr": "s:s5SliceV"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:Swys5SliceVySwGSnySiGcip",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
           "kind": "Function",
           "name": "swapAt",
           "printedName": "swapAt(_:_:)",
-          "declKind": "Func",
-          "usr": "s:Sw6swapAtyySi_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -100902,19 +112831,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw6swapAtyySi_SitF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:Sw5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -100926,10 +112854,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sw5countSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -100937,22 +112861,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sw5countSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sw5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "allocate",
           "printedName": "allocate(byteCount:alignment:)",
-          "declKind": "Func",
-          "usr": "s:Sw8allocate9byteCount9alignmentSwSi_SitFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -100972,39 +112897,37 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw8allocate9byteCount9alignmentSwSi_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "deallocate",
           "printedName": "deallocate()",
-          "declKind": "Func",
-          "usr": "s:Sw10deallocateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw10deallocateyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "load",
           "printedName": "load(fromByteOffset:as:)",
-          "declKind": "Func",
-          "usr": "s:Sw4load14fromByteOffset2asxSi_xmtlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -101030,20 +112953,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw4load14fromByteOffset2asxSi_xmtlF",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "storeBytes",
           "printedName": "storeBytes(of:toByteOffset:as:)",
-          "declKind": "Func",
-          "usr": "s:Sw10storeBytes2of12toByteOffset2asyx_SixmtlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -101074,19 +112996,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw10storeBytes2of12toByteOffset2asyx_SixmtlF",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "copyMemory",
           "printedName": "copyMemory(from:)",
-          "declKind": "Func",
-          "usr": "s:Sw10copyMemory4fromySW_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -101099,20 +113021,18 @@
               "printedName": "UnsafeRawBufferPointer",
               "usr": "s:SW"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw10copyMemory4fromySW_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "copyBytes",
           "printedName": "copyBytes(from:)",
-          "declKind": "Func",
-          "usr": "s:Sw9copyBytes4fromyx_tSlRzs5UInt8V7ElementRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<C where C : Collection, C.Element == UInt8>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -101124,19 +113044,19 @@
               "name": "GenericTypeParam",
               "printedName": "C"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw9copyBytes4fromyx_tSlRzs5UInt8V7ElementRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<C where C : Collection, C.Element == UInt8>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(start:count:)",
-          "declKind": "Constructor",
-          "usr": "s:Sw5start5countSwSvSg_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -101148,7 +113068,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeMutableRawPointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -101156,7 +113075,8 @@
                   "printedName": "UnsafeMutableRawPointer",
                   "usr": "s:Sv"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -101164,19 +113084,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sw5start5countSwSvSg_Sitcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SwyS2wcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -101190,19 +113109,18 @@
               "printedName": "UnsafeMutableRawBufferPointer",
               "usr": "s:Sw"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SwyS2wcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(mutating:)",
-          "declKind": "Constructor",
-          "usr": "s:Sw8mutatingSwSW_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -101216,20 +113134,18 @@
               "printedName": "UnsafeRawBufferPointer",
               "usr": "s:SW"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sw8mutatingSwSW_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SwySwSryxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -101241,28 +113157,28 @@
               "kind": "TypeNominal",
               "name": "UnsafeMutableBufferPointer",
               "printedName": "UnsafeMutableBufferPointer<T>",
-              "usr": "s:Sr",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sr"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SwySwSryxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(rebasing:)",
-          "declKind": "Constructor",
-          "usr": "s:Sw8rebasingSws5SliceVySwG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -101274,7 +113190,6 @@
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<UnsafeMutableRawBufferPointer>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -101282,27 +113197,26 @@
                   "printedName": "UnsafeMutableRawBufferPointer",
                   "usr": "s:Sw"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sw8rebasingSws5SliceVySwG_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "baseAddress",
           "printedName": "baseAddress",
-          "declKind": "Var",
-          "usr": "s:Sw11baseAddressSvSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeMutableRawPointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -101310,22 +113224,18 @@
                   "printedName": "UnsafeMutableRawPointer",
                   "usr": "s:Sv"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sw11baseAddressSvSgvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "UnsafeMutableRawPointer?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -101333,38 +113243,39 @@
                       "printedName": "UnsafeMutableRawPointer",
                       "usr": "s:Sv"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sw11baseAddressSvSgvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sw11baseAddressSvSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "initializeMemory",
           "printedName": "initializeMemory(as:repeating:)",
-          "declKind": "Func",
-          "usr": "s:Sw16initializeMemory2as9repeatingSryxGxm_xtlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutableBufferPointer",
               "printedName": "UnsafeMutableBufferPointer<T>",
-              "usr": "s:Sr",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sr"
             },
             {
               "kind": "TypeNominal",
@@ -101383,20 +113294,20 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw16initializeMemory2as9repeatingSryxGxm_xtlF",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "initializeMemory",
           "printedName": "initializeMemory(as:from:)",
-          "declKind": "Func",
-          "usr": "s:Sw16initializeMemory2as4from8IteratorQz9unwritten_Sry7ElementQzG11initializedtAHm_xtSTRzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<S where S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -101412,14 +113323,14 @@
                   "kind": "TypeNominal",
                   "name": "UnsafeMutableBufferPointer",
                   "printedName": "UnsafeMutableBufferPointer<S.Element>",
-                  "usr": "s:Sr",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "DependentMember",
                       "printedName": "S.Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sr"
                 }
               ]
             },
@@ -101440,34 +113351,32 @@
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw16initializeMemory2as4from8IteratorQz9unwritten_Sry7ElementQzG11initializedtAHm_xtSTRzlF",
+          "moduleName": "Swift",
+          "genericSig": "<S where S : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "bindMemory",
           "printedName": "bindMemory(to:)",
-          "declKind": "Func",
-          "usr": "s:Sw10bindMemory2toSryxGxm_tlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutableBufferPointer",
               "printedName": "UnsafeMutableBufferPointer<T>",
-              "usr": "s:Sr",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sr"
             },
             {
               "kind": "TypeNominal",
@@ -101481,16 +113390,20 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw10bindMemory2toSryxGxm_tlF",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:Sw16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -101502,10 +113415,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sw16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -101513,22 +113422,20 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sw16debugDescriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sw16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "allocate",
           "printedName": "allocate(count:)",
-          "declKind": "Func",
-          "usr": "s:Sw8allocate5countSwSi_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -101542,19 +113449,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw8allocate5countSwSi_tFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "copyBytes",
           "printedName": "copyBytes(from:)",
-          "declKind": "Func",
-          "usr": "s:Sw9copyBytes4fromySW_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -101567,63 +113475,50 @@
               "printedName": "UnsafeRawBufferPointer",
               "usr": "s:SW"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sw9copyBytes4fromySW_tF",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:Sw",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "MutableCollection",
+        "Collection",
+        "RandomAccessCollection",
+        "BidirectionalCollection",
+        "CustomDebugStringConvertible"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnsafeRawBufferPointer",
       "printedName": "UnsafeRawBufferPointer",
-      "declKind": "Struct",
-      "usr": "s:SW",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Sequence",
-        "Collection",
-        "RandomAccessCollection",
-        "BidirectionalCollection",
-        "CustomDebugStringConvertible"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:SW8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "IteratorProtocol",
-            "Sequence"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:SW8IteratorV4nexts5UInt8VSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "UInt8?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -101631,18 +113526,22 @@
                       "printedName": "UInt8",
                       "usr": "s:s5UInt8V"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:SW8IteratorV4nexts5UInt8VSgyF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:SW8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -101650,16 +113549,16 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SW8IteratorV7Elementa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "Iterator",
               "printedName": "Iterator",
-              "declKind": "TypeAlias",
-              "usr": "s:SW8IteratorVAAa",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -101667,22 +113566,21 @@
                   "printedName": "UnsafeRawBufferPointer.Iterator",
                   "usr": "s:SW8IteratorV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SW8IteratorVAAa",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "SubSequence",
               "printedName": "SubSequence",
-              "declKind": "TypeAlias",
-              "usr": "s:SW8IteratorV11SubSequencea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnySequence",
                   "printedName": "AnySequence<UnsafeRawBufferPointer.Iterator.Element>",
-                  "usr": "s:s11AnySequenceV",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -101697,26 +113595,36 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:s11AnySequenceV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:SW8IteratorV11SubSequencea",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:SW8IteratorV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol",
+            "Sequence"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:SW11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<UnsafeRawBufferPointer>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -101724,21 +113632,18 @@
                   "printedName": "UnsafeRawBufferPointer",
                   "usr": "s:SW"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SW11SubSequencea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:SW12makeIteratorSW0B0VyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -101746,16 +113651,18 @@
               "printedName": "UnsafeRawBufferPointer.Iterator",
               "usr": "s:SW8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SW12makeIteratorSW0B0VyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:SW7Elementa",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -101763,16 +113670,15 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SW7Elementa",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:SW5Indexa",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -101780,22 +113686,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SW5Indexa",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:SW7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Int>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -101803,21 +113707,18 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SW7Indicesa",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:SW10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -101836,10 +113737,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SW10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -101854,21 +113751,23 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SW10startIndexSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SW10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:SW8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -101887,10 +113786,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SW8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -101905,21 +113800,23 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SW8endIndexSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SW8endIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "indices",
           "printedName": "indices",
-          "declKind": "Var",
-          "usr": "s:SW7indicesSnySiGvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -101930,7 +113827,6 @@
                   "kind": "TypeNominal",
                   "name": "Range",
                   "printedName": "Range<Int>",
-                  "usr": "s:Sn",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -101938,7 +113834,8 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sn"
                 }
               ]
             },
@@ -101946,10 +113843,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SW7indicesSnySiGvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -101960,7 +113853,6 @@
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -101968,25 +113860,108 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SW7indicesSnySiGvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SW7indicesSnySiGvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Element",
+              "printedName": "UnsafeRawBufferPointer.Element",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UInt8",
+                  "printedName": "UInt8",
+                  "usr": "s:s5UInt8V"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SWys5UInt8VSicip",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "SubSequence",
+              "printedName": "UnsafeRawBufferPointer.SubSequence",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Slice",
+                  "printedName": "Slice<UnsafeRawBufferPointer>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "UnsafeRawBufferPointer",
+                      "printedName": "UnsafeRawBufferPointer",
+                      "usr": "s:SW"
+                    }
+                  ],
+                  "usr": "s:s5SliceV"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SWys5SliceVySWGSnySiGcip",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:SW5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -101998,10 +113973,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SW5countSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -102009,41 +113980,41 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SW5countSivg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SW5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "deallocate",
           "printedName": "deallocate()",
-          "declKind": "Func",
-          "usr": "s:SW10deallocateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SW10deallocateyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "load",
           "printedName": "load(fromByteOffset:as:)",
-          "declKind": "Func",
-          "usr": "s:SW4load14fromByteOffset2asxSi_xmtlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102069,19 +114040,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SW4load14fromByteOffset2asxSi_xmtlF",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(start:count:)",
-          "declKind": "Constructor",
-          "usr": "s:SW5start5countSWSVSg_Sitcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102093,7 +114064,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeRawPointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -102101,7 +114071,8 @@
                   "printedName": "UnsafeRawPointer",
                   "usr": "s:SV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -102109,19 +114080,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SW5start5countSWSVSg_Sitcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SWySWSwcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102135,19 +114105,18 @@
               "printedName": "UnsafeMutableRawBufferPointer",
               "usr": "s:Sw"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SWySWSwcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SWyS2Wcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102161,20 +114130,18 @@
               "printedName": "UnsafeRawBufferPointer",
               "usr": "s:SW"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SWyS2Wcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SWySWSryxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102186,29 +114153,28 @@
               "kind": "TypeNominal",
               "name": "UnsafeMutableBufferPointer",
               "printedName": "UnsafeMutableBufferPointer<T>",
-              "usr": "s:Sr",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sr"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SWySWSryxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SWySWSRyxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102220,28 +114186,28 @@
               "kind": "TypeNominal",
               "name": "UnsafeBufferPointer",
               "printedName": "UnsafeBufferPointer<T>",
-              "usr": "s:SR",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:SR"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SWySWSRyxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(rebasing:)",
-          "declKind": "Constructor",
-          "usr": "s:SW8rebasingSWs5SliceVySWG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102253,7 +114219,6 @@
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<UnsafeRawBufferPointer>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -102261,21 +114226,21 @@
                   "printedName": "UnsafeRawBufferPointer",
                   "usr": "s:SW"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SW8rebasingSWs5SliceVySWG_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(rebasing:)",
-          "declKind": "Constructor",
-          "usr": "s:SW8rebasingSWs5SliceVySwG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102287,7 +114252,6 @@
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<UnsafeMutableRawBufferPointer>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -102295,27 +114259,26 @@
                   "printedName": "UnsafeMutableRawBufferPointer",
                   "usr": "s:Sw"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SW8rebasingSWs5SliceVySwG_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "baseAddress",
           "printedName": "baseAddress",
-          "declKind": "Var",
-          "usr": "s:SW11baseAddressSVSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeRawPointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -102323,22 +114286,18 @@
                   "printedName": "UnsafeRawPointer",
                   "usr": "s:SV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SW11baseAddressSVSgvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "UnsafeRawPointer?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -102346,38 +114305,39 @@
                       "printedName": "UnsafeRawPointer",
                       "usr": "s:SV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SW11baseAddressSVSgvg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SW11baseAddressSVSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "bindMemory",
           "printedName": "bindMemory(to:)",
-          "declKind": "Func",
-          "usr": "s:SW10bindMemory2toSRyxGxm_tlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeBufferPointer",
               "printedName": "UnsafeBufferPointer<T>",
-              "usr": "s:SR",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:SR"
             },
             {
               "kind": "TypeNominal",
@@ -102391,16 +114351,20 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SW10bindMemory2toSRyxGxm_tlF",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Transparent"
           ]
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:SW16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -102412,10 +114376,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SW16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -102423,26 +114383,35 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SW16debugDescriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SW16debugDescriptionSSvp",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:SW",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "Collection",
+        "RandomAccessCollection",
+        "BidirectionalCollection",
+        "CustomDebugStringConvertible"
       ]
     },
     {
       "kind": "Function",
       "name": "withUnsafeMutableBytes",
       "printedName": "withUnsafeMutableBytes(of:_:)",
-      "declKind": "Func",
-      "usr": "s:s22withUnsafeMutableBytes2of_q_xz_q_SwKXEtKr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, Result>",
-      "throwing": true,
-      "declAttributes": [
-        "Rethrows",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -102458,9 +114427,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "(UnsafeMutableRawBufferPointer) throws -> Result",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102471,7 +114437,6 @@
               "kind": "TypeNominal",
               "name": "Paren",
               "printedName": "(UnsafeMutableRawBufferPointer)",
-              "usr": "s:Sw",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -102479,82 +114444,84 @@
                   "printedName": "UnsafeMutableRawBufferPointer",
                   "usr": "s:Sw"
                 }
-              ]
+              ],
+              "usr": "s:Sw"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         }
-      ]
+      ],
+      "declKind": "Func",
+      "usr": "s:s22withUnsafeMutableBytes2of_q_xz_q_SwKXEtKr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<T, Result>",
+      "declAttributes": [
+        "Rethrows",
+        "Inlinable"
+      ],
+      "throwing": true
     },
     {
       "kind": "Function",
       "name": "withUnsafeBytes",
       "printedName": "withUnsafeBytes(of:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "Result"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "GenericTypeParam",
+          "printedName": "T"
+        },
+        {
+          "kind": "TypeFunc",
+          "name": "Function",
+          "printedName": "(UnsafeRawBufferPointer) throws -> Result",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Result"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Paren",
+              "printedName": "(UnsafeRawBufferPointer)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "UnsafeRawBufferPointer",
+                  "printedName": "UnsafeRawBufferPointer",
+                  "usr": "s:SW"
+                }
+              ],
+              "usr": "s:SW"
+            }
+          ],
+          "typeAttributes": [
+            "noescape"
+          ]
+        }
+      ],
       "declKind": "Func",
       "usr": "s:s15withUnsafeBytes2of_q_xz_q_SWKXEtKr0_lF",
-      "location": "",
       "moduleName": "Swift",
       "genericSig": "<T, Result>",
-      "throwing": true,
       "declAttributes": [
         "Rethrows",
         "Inlinable"
       ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "Result"
-        },
-        {
-          "kind": "TypeNominal",
-          "name": "GenericTypeParam",
-          "printedName": "T"
-        },
-        {
-          "kind": "TypeFunc",
-          "name": "Function",
-          "printedName": "(UnsafeRawBufferPointer) throws -> Result",
-          "typeAttributes": [
-            "noescape"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Result"
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Paren",
-              "printedName": "(UnsafeRawBufferPointer)",
-              "usr": "s:SW",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "UnsafeRawBufferPointer",
-                  "printedName": "UnsafeRawBufferPointer",
-                  "usr": "s:SW"
-                }
-              ]
-            }
-          ]
-        }
-      ]
+      "throwing": true
     },
     {
       "kind": "Function",
       "name": "withUnsafeBytes",
       "printedName": "withUnsafeBytes(of:_:)",
-      "declKind": "Func",
-      "usr": "s:s15withUnsafeBytes2of_q_x_q_SWKXEtKr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, Result>",
-      "throwing": true,
-      "declAttributes": [
-        "Rethrows",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -102570,9 +114537,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "(UnsafeRawBufferPointer) throws -> Result",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102583,7 +114547,6 @@
               "kind": "TypeNominal",
               "name": "Paren",
               "printedName": "(UnsafeRawBufferPointer)",
-              "usr": "s:SW",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -102591,45 +114554,34 @@
                   "printedName": "UnsafeRawBufferPointer",
                   "usr": "s:SW"
                 }
-              ]
+              ],
+              "usr": "s:SW"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         }
-      ]
+      ],
+      "declKind": "Func",
+      "usr": "s:s15withUnsafeBytes2of_q_x_q_SWKXEtKr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<T, Result>",
+      "declAttributes": [
+        "Rethrows",
+        "Inlinable"
+      ],
+      "throwing": true
     },
     {
       "kind": "TypeDecl",
       "name": "UnsafePointer",
       "printedName": "UnsafePointer",
-      "declKind": "Struct",
-      "usr": "s:SP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Pointee>",
-      "conformingProtocols": [
-        "_Pointer",
-        "Hashable",
-        "Strideable",
-        "CustomDebugStringConvertible",
-        "CustomReflectable",
-        "Equatable",
-        "Comparable",
-        "_CustomPlaygroundQuickLookable",
-        "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Distance",
           "printedName": "Distance",
-          "declKind": "TypeAlias",
-          "usr": "s:SP8Distancea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -102637,39 +114589,35 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SP8Distancea",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>"
         },
         {
           "kind": "Function",
           "name": "deallocate",
           "printedName": "deallocate()",
-          "declKind": "Func",
-          "usr": "s:SP10deallocateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SP10deallocateyyF",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "pointee",
           "printedName": "pointee",
-          "declKind": "Var",
-          "usr": "s:SP7pointeexvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102680,38 +114628,34 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SP7pointeexvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Pointee>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Pointee"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SP7pointeexvg",
+              "moduleName": "Swift",
+              "genericSig": "<Pointee>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SP7pointeexvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "withMemoryRebound",
           "printedName": "withMemoryRebound(to:capacity:_:)",
-          "declKind": "Func",
-          "usr": "s:SP17withMemoryRebound2to8capacity_qd_0_qd__m_Siqd_0_SPyqd__GKXEtKr0_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee, T, Result>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -102740,9 +114684,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafePointer<T>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -102753,53 +114694,92 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafePointer<T>)",
-                  "usr": "s:SP",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafePointer",
                       "printedName": "UnsafePointer<T>",
-                      "usr": "s:SP",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
                           "printedName": "T"
                         }
-                      ]
+                      ],
+                      "usr": "s:SP"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SP17withMemoryRebound2to8capacity_qd_0_qd__m_Siqd_0_SPyqd__GKXEtKr0_lF",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee, T, Result>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Pointee",
+              "printedName": "UnsafePointer<Pointee>.Pointee",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SPyxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Pointee",
           "printedName": "Pointee",
-          "declKind": "TypeAlias",
-          "usr": "s:SP7Pointeea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Pointee"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SP7Pointeea",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:SP6Stridea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -102807,16 +114787,17 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SP6Stridea",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SP9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -102828,11 +114809,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SP9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Pointee>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -102840,22 +114816,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SP9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Pointee>",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SP9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:SP25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -102874,11 +114851,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SP25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Pointee>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -102893,21 +114865,29 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SP25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift",
+              "genericSig": "<Pointee>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SP25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
-      "name": "UnsafeMutablePointer",
-      "printedName": "UnsafeMutablePointer",
+      ],
       "declKind": "Struct",
-      "usr": "s:Sp",
-      "location": "",
+      "usr": "s:SP",
       "moduleName": "Swift",
       "genericSig": "<Pointee>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
       "conformingProtocols": [
         "_Pointer",
         "Hashable",
@@ -102918,20 +114898,17 @@
         "Comparable",
         "_CustomPlaygroundQuickLookable",
         "CVarArg"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "UnsafeMutablePointer",
+      "printedName": "UnsafeMutablePointer",
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Distance",
           "printedName": "Distance",
-          "declKind": "TypeAlias",
-          "usr": "s:Sp8Distancea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -102939,39 +114916,34 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sp8Distancea",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(mutating:)",
-          "declKind": "Constructor",
-          "usr": "s:Sp8mutatingSpyxGSPyxG_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
               "printedName": "UnsafeMutablePointer<Pointee>",
-              "usr": "s:Sp",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Pointee"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<UnsafeMutablePointer<Pointee>.Pointee>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -102985,55 +114957,53 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:SP"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sp8mutatingSpyxGSPyxG_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(mutating:)",
-          "declKind": "Constructor",
-          "usr": "s:Sp8mutatingSpyxGSgSPyxGSg_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeMutablePointer<Pointee>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafeMutablePointer",
                   "printedName": "UnsafeMutablePointer<Pointee>",
-                  "usr": "s:Sp",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Pointee"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafePointer<UnsafeMutablePointer<Pointee>.Pointee>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafePointer",
                   "printedName": "UnsafePointer<UnsafeMutablePointer<Pointee>.Pointee>",
-                  "usr": "s:SP",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -103047,31 +115017,30 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sp8mutatingSpyxGSgSPyxGSg_tcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "allocate",
           "printedName": "allocate(capacity:)",
-          "declKind": "Func",
-          "usr": "s:Sp8allocate8capacitySpyxGSi_tFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
               "printedName": "UnsafeMutablePointer<UnsafeMutablePointer<Pointee>.Pointee>",
-              "usr": "s:Sp",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -103085,7 +115054,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
@@ -103093,39 +115063,39 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp8allocate8capacitySpyxGSi_tFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "deallocate",
           "printedName": "deallocate()",
-          "declKind": "Func",
-          "usr": "s:Sp10deallocateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp10deallocateyyF",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "pointee",
           "printedName": "pointee",
-          "declKind": "Var",
-          "usr": "s:Sp7pointeexvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103136,34 +115106,26 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sp7pointeexvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Pointee>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Pointee"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sp7pointeexvg",
+              "moduleName": "Swift",
+              "genericSig": "<Pointee>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Setter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sp7pointeexvs",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Pointee>",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -103175,22 +115137,28 @@
                   "name": "GenericTypeParam",
                   "printedName": "Pointee"
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sp7pointeexvs",
+              "moduleName": "Swift",
+              "genericSig": "<Pointee>",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
               ]
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sp7pointeexvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "initialize",
           "printedName": "initialize(repeating:count:)",
-          "declKind": "Func",
-          "usr": "s:Sp10initialize9repeating5countyx_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103208,20 +115176,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp10initialize9repeating5countyx_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "initialize",
           "printedName": "initialize(to:)",
-          "declKind": "Func",
-          "usr": "s:Sp10initialize2toyx_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103233,20 +115200,19 @@
               "name": "GenericTypeParam",
               "printedName": "Pointee"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp10initialize2toyx_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "move",
           "printedName": "move()",
-          "declKind": "Func",
-          "usr": "s:Sp4movexyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -103260,20 +115226,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp4movexyF",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "assign",
           "printedName": "assign(repeating:count:)",
-          "declKind": "Func",
-          "usr": "s:Sp6assign9repeating5countyx_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103298,20 +115263,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp6assign9repeating5countyx_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "assign",
           "printedName": "assign(from:count:)",
-          "declKind": "Func",
-          "usr": "s:Sp6assign4from5countySPyxG_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103322,7 +115286,6 @@
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<UnsafeMutablePointer<Pointee>.Pointee>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -103336,7 +115299,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:SP"
             },
             {
               "kind": "TypeNominal",
@@ -103344,20 +115308,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp6assign4from5countySPyxG_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "moveInitialize",
           "printedName": "moveInitialize(from:count:)",
-          "declKind": "Func",
-          "usr": "s:Sp14moveInitialize4from5countySpyxG_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103368,14 +115331,14 @@
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
               "printedName": "UnsafeMutablePointer<Pointee>",
-              "usr": "s:Sp",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Pointee"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
@@ -103383,20 +115346,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp14moveInitialize4from5countySpyxG_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "initialize",
           "printedName": "initialize(from:count:)",
-          "declKind": "Func",
-          "usr": "s:Sp10initialize4from5countySPyxG_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103407,14 +115369,14 @@
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<Pointee>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Pointee"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             },
             {
               "kind": "TypeNominal",
@@ -103422,20 +115384,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp10initialize4from5countySPyxG_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "moveAssign",
           "printedName": "moveAssign(from:count:)",
-          "declKind": "Func",
-          "usr": "s:Sp10moveAssign4from5countySpyxG_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103446,14 +115407,14 @@
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
               "printedName": "UnsafeMutablePointer<Pointee>",
-              "usr": "s:Sp",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Pointee"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
@@ -103461,21 +115422,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp10moveAssign4from5countySpyxG_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "deinitialize",
           "printedName": "deinitialize(count:)",
-          "declKind": "Func",
-          "usr": "s:Sp12deinitialize5countSvSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103489,22 +115448,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp12deinitialize5countSvSi_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "withMemoryRebound",
           "printedName": "withMemoryRebound(to:capacity:_:)",
-          "declKind": "Func",
-          "usr": "s:Sp17withMemoryRebound2to8capacity_qd_0_qd__m_Siqd_0_Spyqd__GKXEtKr0_lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee, T, Result>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103533,9 +115490,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(UnsafeMutablePointer<T>) throws -> Result",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -103546,36 +115500,76 @@
                   "kind": "TypeNominal",
                   "name": "Paren",
                   "printedName": "(UnsafeMutablePointer<T>)",
-                  "usr": "s:Sp",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafeMutablePointer",
                       "printedName": "UnsafeMutablePointer<T>",
-                      "usr": "s:Sp",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
                           "printedName": "T"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sp"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp17withMemoryRebound2to8capacity_qd_0_qd__m_Siqd_0_Spyqd__GKXEtKr0_lF",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee, T, Result>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "Pointee",
+              "printedName": "UnsafeMutablePointer<Pointee>.Pointee",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "τ_0_0"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:SpyxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:Sp6Stridea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -103583,33 +115577,34 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sp6Stridea",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Pointee",
           "printedName": "Pointee",
-          "declKind": "TypeAlias",
-          "usr": "s:Sp7Pointeea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Pointee"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sp7Pointeea",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Sp9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -103621,11 +115616,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sp9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Pointee>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -103633,22 +115623,23 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sp9hashValueSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Pointee>",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sp9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "initialize",
           "printedName": "initialize(to:count:)",
-          "declKind": "Func",
-          "usr": "s:Sp10initialize2to5countyx_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103667,21 +115658,20 @@
               "hasDefaultArg": true,
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp10initialize2to5countyx_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "deinitialize",
           "printedName": "deinitialize()",
-          "declKind": "Func",
-          "usr": "s:Sp12deinitializeSvyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103689,20 +115679,21 @@
               "printedName": "UnsafeMutableRawPointer",
               "usr": "s:Sv"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp12deinitializeSvyF",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "deprecated": true,
+          "declAttributes": [
+            "DiscardableResult",
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "deallocate",
           "printedName": "deallocate(capacity:)",
-          "declKind": "Func",
-          "usr": "s:Sp10deallocate8capacityySi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee>",
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103715,21 +115706,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp10deallocate8capacityySi_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "initialize",
           "printedName": "initialize(from:)",
-          "declKind": "Func",
-          "usr": "s:Sp10initialize4fromyqd___t7ElementQyd__RszSlRd__lF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Pointee, C where Pointee == C.Element, C : Collection>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103741,20 +115731,20 @@
               "name": "GenericTypeParam",
               "printedName": "C"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sp10initialize4fromyqd___t7ElementQyd__RszSlRd__lF",
+          "moduleName": "Swift",
+          "genericSig": "<Pointee, C where Pointee == C.Element, C : Collection>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:Sp25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -103773,11 +115763,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sp25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Pointee>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -103792,42 +115777,50 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sp25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift",
+              "genericSig": "<Pointee>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sp25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:Sp",
+      "moduleName": "Swift",
+      "genericSig": "<Pointee>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "_Pointer",
+        "Hashable",
+        "Strideable",
+        "CustomDebugStringConvertible",
+        "CustomReflectable",
+        "Equatable",
+        "Comparable",
+        "_CustomPlaygroundQuickLookable",
+        "CVarArg"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnsafeRawPointer",
       "printedName": "UnsafeRawPointer",
-      "declKind": "Struct",
-      "usr": "s:SV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "_Pointer",
-        "Hashable",
-        "CustomDebugStringConvertible",
-        "CustomReflectable",
-        "Strideable",
-        "Comparable",
-        "Equatable",
-        "_CustomPlaygroundQuickLookable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Pointee",
           "printedName": "Pointee",
-          "declKind": "TypeAlias",
-          "usr": "s:SV7Pointeea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -103835,20 +115828,15 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SV7Pointeea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SVySVSPyxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103860,35 +115848,33 @@
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<T>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SVySVSPyxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SVySVSgSPyxGSgclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeRawPointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -103896,42 +115882,43 @@
                   "printedName": "UnsafeRawPointer",
                   "usr": "s:SV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafePointer<T>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafePointer",
                   "printedName": "UnsafePointer<T>",
-                  "usr": "s:SP",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "T"
                     }
-                  ]
+                  ],
+                  "usr": "s:SP"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SVySVSgSPyxGSgclufc",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SVySVSvcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -103945,25 +115932,23 @@
               "printedName": "UnsafeMutableRawPointer",
               "usr": "s:Sv"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SVySVSvcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SVySVSgSvSgcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeRawPointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -103971,13 +115956,13 @@
                   "printedName": "UnsafeRawPointer",
                   "usr": "s:SV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeMutableRawPointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -103985,55 +115970,52 @@
                   "printedName": "UnsafeMutableRawPointer",
                   "usr": "s:Sv"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SVySVSgSvSgcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "deallocate",
           "printedName": "deallocate()",
-          "declKind": "Func",
-          "usr": "s:SV10deallocateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SV10deallocateyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "bindMemory",
           "printedName": "bindMemory(to:capacity:)",
-          "declKind": "Func",
-          "usr": "s:SV10bindMemory2to8capacitySPyxGxm_SitlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<T>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             },
             {
               "kind": "TypeNominal",
@@ -104053,33 +116035,33 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SV10bindMemory2to8capacitySPyxGxm_SitlF",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "assumingMemoryBound",
           "printedName": "assumingMemoryBound(to:)",
-          "declKind": "Func",
-          "usr": "s:SV19assumingMemoryBound2toSPyxGxm_tlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<T>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             },
             {
               "kind": "TypeNominal",
@@ -104093,20 +116075,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SV19assumingMemoryBound2toSPyxGxm_tlF",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "load",
           "printedName": "load(fromByteOffset:as:)",
-          "declKind": "Func",
-          "usr": "s:SV4load14fromByteOffset2asxSi_xmtlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104132,16 +116113,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SV4load14fromByteOffset2asxSi_xmtlF",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:SV9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -104153,10 +116137,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SV9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -104164,22 +116144,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SV9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:SV9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SVySVSAyxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104191,35 +116171,33 @@
               "kind": "TypeNominal",
               "name": "AutoreleasingUnsafeMutablePointer",
               "printedName": "AutoreleasingUnsafeMutablePointer<T>",
-              "usr": "s:SA",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:SA"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SVySVSAyxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SVySVSgSAyxGSgclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeRawPointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -104227,42 +116205,43 @@
                   "printedName": "UnsafeRawPointer",
                   "usr": "s:SV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "AutoreleasingUnsafeMutablePointer<T>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AutoreleasingUnsafeMutablePointer",
                   "printedName": "AutoreleasingUnsafeMutablePointer<T>",
-                  "usr": "s:SA",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "T"
                     }
-                  ]
+                  ],
+                  "usr": "s:SA"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SVySVSgSAyxGSgclufc",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "advanced",
           "printedName": "advanced(by:)",
-          "declKind": "Func",
-          "usr": "s:SV8advanced2bySVSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104276,16 +116255,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:SV8advanced2bySVSi_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:SV6Stridea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -104293,20 +116274,16 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:SV6Stridea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:SV25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104318,10 +116295,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:SV25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -104329,42 +116302,47 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:SV25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:SV25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:SV",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "_Pointer",
+        "Hashable",
+        "CustomDebugStringConvertible",
+        "CustomReflectable",
+        "Strideable",
+        "Comparable",
+        "Equatable",
+        "_CustomPlaygroundQuickLookable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnsafeMutableRawPointer",
       "printedName": "UnsafeMutableRawPointer",
-      "declKind": "Struct",
-      "usr": "s:Sv",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "_Pointer",
-        "Hashable",
-        "CustomDebugStringConvertible",
-        "CustomReflectable",
-        "Strideable",
-        "Comparable",
-        "Equatable",
-        "_CustomPlaygroundQuickLookable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeAlias",
           "name": "Pointee",
           "printedName": "Pointee",
-          "declKind": "TypeAlias",
-          "usr": "s:Sv7Pointeea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -104372,20 +116350,15 @@
               "printedName": "UInt8",
               "usr": "s:s5UInt8V"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sv7Pointeea",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SvySvSpyxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104397,35 +116370,33 @@
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
               "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SvySvSpyxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SvySvSgSpyxGSgclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeMutableRawPointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -104433,42 +116404,43 @@
                   "printedName": "UnsafeMutableRawPointer",
                   "usr": "s:Sv"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeMutablePointer<T>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafeMutablePointer",
                   "printedName": "UnsafeMutablePointer<T>",
-                  "usr": "s:Sp",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "T"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SvySvSgSpyxGSgclufc",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(mutating:)",
-          "declKind": "Constructor",
-          "usr": "s:Sv8mutatingSvSV_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104482,25 +116454,23 @@
               "printedName": "UnsafeRawPointer",
               "usr": "s:SV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sv8mutatingSvSV_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(mutating:)",
-          "declKind": "Constructor",
-          "usr": "s:Sv8mutatingSvSgSVSg_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeMutableRawPointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -104508,13 +116478,13 @@
                   "printedName": "UnsafeMutableRawPointer",
                   "usr": "s:Sv"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeRawPointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -104522,22 +116492,21 @@
                   "printedName": "UnsafeRawPointer",
                   "usr": "s:SV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:Sv8mutatingSvSgSVSg_tcfc",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "allocate",
           "printedName": "allocate(byteCount:alignment:)",
-          "declKind": "Func",
-          "usr": "s:Sv8allocate9byteCount9alignmentSvSi_SitFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104557,53 +116526,50 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv8allocate9byteCount9alignmentSvSi_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "deallocate",
           "printedName": "deallocate()",
-          "declKind": "Func",
-          "usr": "s:Sv10deallocateyyF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Void",
               "printedName": "()"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv10deallocateyyF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "bindMemory",
           "printedName": "bindMemory(to:capacity:)",
-          "declKind": "Func",
-          "usr": "s:Sv10bindMemory2to8capacitySpyxGxm_SitlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
               "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
@@ -104623,33 +116589,33 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv10bindMemory2to8capacitySpyxGxm_SitlF",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "assumingMemoryBound",
           "printedName": "assumingMemoryBound(to:)",
-          "declKind": "Func",
-          "usr": "s:Sv19assumingMemoryBound2toSpyxGxm_tlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
               "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
@@ -104663,34 +116629,32 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv19assumingMemoryBound2toSpyxGxm_tlF",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "initializeMemory",
           "printedName": "initializeMemory(as:repeating:count:)",
-          "declKind": "Func",
-          "usr": "s:Sv16initializeMemory2as9repeating5countSpyxGxm_xSitlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
               "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
@@ -104715,34 +116679,33 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv16initializeMemory2as9repeating5countSpyxGxm_xSitlF",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "initializeMemory",
           "printedName": "initializeMemory(as:from:count:)",
-          "declKind": "Func",
-          "usr": "s:Sv16initializeMemory2as4from5countSpyxGxm_SPyxGSitlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
               "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
@@ -104760,14 +116723,14 @@
               "kind": "TypeNominal",
               "name": "UnsafePointer",
               "printedName": "UnsafePointer<T>",
-              "usr": "s:SP",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:SP"
             },
             {
               "kind": "TypeNominal",
@@ -104775,34 +116738,33 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv16initializeMemory2as4from5countSpyxGxm_SPyxGSitlF",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "moveInitializeMemory",
           "printedName": "moveInitializeMemory(as:from:count:)",
-          "declKind": "Func",
-          "usr": "s:Sv20moveInitializeMemory2as4from5countSpyxGxm_AESitlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
               "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
@@ -104820,14 +116782,14 @@
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
               "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
@@ -104835,20 +116797,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv20moveInitializeMemory2as4from5countSpyxGxm_AESitlF",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "DiscardableResult",
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "load",
           "printedName": "load(fromByteOffset:as:)",
-          "declKind": "Func",
-          "usr": "s:Sv4load14fromByteOffset2asxSi_xmtlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104874,20 +116836,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv4load14fromByteOffset2asxSi_xmtlF",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "storeBytes",
           "printedName": "storeBytes(of:toByteOffset:as:)",
-          "declKind": "Func",
-          "usr": "s:Sv10storeBytes2of12toByteOffset2asyx_SixmtlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104918,19 +116879,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv10storeBytes2of12toByteOffset2asyx_SixmtlF",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "copyMemory",
           "printedName": "copyMemory(from:byteCount:)",
-          "declKind": "Func",
-          "usr": "s:Sv10copyMemory4from9byteCountySV_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -104949,16 +116910,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv10copyMemory4from9byteCountySV_SitF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "hashValue",
           "printedName": "hashValue",
-          "declKind": "Var",
-          "usr": "s:Sv9hashValueSivp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -104970,10 +116933,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sv9hashValueSivg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -104981,22 +116940,22 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sv9hashValueSivg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:Sv9hashValueSivp",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SvySvSAyxGclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -105008,35 +116967,33 @@
               "kind": "TypeNominal",
               "name": "AutoreleasingUnsafeMutablePointer",
               "printedName": "AutoreleasingUnsafeMutablePointer<T>",
-              "usr": "s:SA",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:SA"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SvySvSAyxGclufc",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:SvySvSgSAyxGSgclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Transparent"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "UnsafeMutableRawPointer?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -105044,42 +117001,43 @@
                   "printedName": "UnsafeMutableRawPointer",
                   "usr": "s:Sv"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "AutoreleasingUnsafeMutablePointer<T>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AutoreleasingUnsafeMutablePointer",
                   "printedName": "AutoreleasingUnsafeMutablePointer<T>",
-                  "usr": "s:SA",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "T"
                     }
-                  ]
+                  ],
+                  "usr": "s:SA"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:SvySvSgSAyxGSgclufc",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Transparent"
           ]
         },
         {
           "kind": "Function",
           "name": "advanced",
           "printedName": "advanced(by:)",
-          "declKind": "Func",
-          "usr": "s:Sv8advanced2bySvSi_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -105093,16 +117051,18 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv8advanced2bySvSi_tF",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Stride",
           "printedName": "Stride",
-          "declKind": "TypeAlias",
-          "usr": "s:Sv6Stridea",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -105110,20 +117070,16 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:Sv6Stridea",
+          "moduleName": "Swift",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "customPlaygroundQuickLook",
           "printedName": "customPlaygroundQuickLook",
-          "declKind": "Var",
-          "usr": "s:Sv25customPlaygroundQuickLooks01_bcD0Ovp",
-          "location": "",
-          "moduleName": "Swift",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -105135,10 +117091,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:Sv25customPlaygroundQuickLooks01_bcD0Ovg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -105146,22 +117098,24 @@
                   "printedName": "_PlaygroundQuickLook",
                   "usr": "s:s20_PlaygroundQuickLookO"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:Sv25customPlaygroundQuickLooks01_bcD0Ovg",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:Sv25customPlaygroundQuickLooks01_bcD0Ovp",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "allocate",
           "printedName": "allocate(bytes:alignedTo:)",
-          "declKind": "Func",
-          "usr": "s:Sv8allocate5bytes9alignedToSvSi_SitFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -105181,19 +117135,20 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv8allocate5bytes9alignedToSvSi_SitFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "deallocate",
           "printedName": "deallocate(bytes:alignedTo:)",
-          "declKind": "Func",
-          "usr": "s:Sv10deallocate5bytes9alignedToySi_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -105212,19 +117167,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv10deallocate5bytes9alignedToySi_SitF",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "copyBytes",
           "printedName": "copyBytes(from:count:)",
-          "declKind": "Func",
-          "usr": "s:Sv9copyBytes4from5countySV_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -105243,34 +117198,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv9copyBytes4from5countySV_SitF",
+          "moduleName": "Swift",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "initializeMemory",
           "printedName": "initializeMemory(as:at:count:to:)",
-          "declKind": "Func",
-          "usr": "s:Sv16initializeMemory2as2at5count2toSpyxGxm_S2ixtlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "DiscardableResult",
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
               "printedName": "UnsafeMutablePointer<T>",
-              "usr": "s:Sp",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
@@ -105303,35 +117256,34 @@
               "name": "GenericTypeParam",
               "printedName": "T"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv16initializeMemory2as2at5count2toSpyxGxm_S2ixtlF",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "deprecated": true,
+          "declAttributes": [
+            "DiscardableResult",
+            "Available"
           ]
         },
         {
           "kind": "Function",
           "name": "initializeMemory",
           "printedName": "initializeMemory(as:from:)",
-          "declKind": "Func",
-          "usr": "s:Sv16initializeMemory2as4fromSpy7ElementQzGAEm_xtSlRzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<C where C : Collection>",
-          "deprecated": true,
-          "declAttributes": [
-            "DiscardableResult",
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
               "printedName": "UnsafeMutablePointer<C.Element>",
-              "usr": "s:Sp",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "C.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "TypeNominal",
@@ -105350,33 +117302,44 @@
               "name": "GenericTypeParam",
               "printedName": "C"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:Sv16initializeMemory2as4fromSpy7ElementQzGAEm_xtSlRzlF",
+          "moduleName": "Swift",
+          "genericSig": "<C where C : Collection>",
+          "deprecated": true,
+          "declAttributes": [
+            "DiscardableResult",
+            "Available"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:Sv",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "_Pointer",
+        "Hashable",
+        "CustomDebugStringConvertible",
+        "CustomReflectable",
+        "Strideable",
+        "Comparable",
+        "Equatable",
+        "_CustomPlaygroundQuickLookable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnicodeDecodingResult",
       "printedName": "UnicodeDecodingResult",
-      "declKind": "Enum",
-      "usr": "s:s21UnicodeDecodingResultO",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Equatable"
-      ],
-      "declAttributes": [
-        "Frozen"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "scalarValue",
           "printedName": "scalarValue",
-          "declKind": "EnumElement",
-          "usr": "s:s21UnicodeDecodingResultO11scalarValueyABs0A0O6ScalarVcABmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -105398,7 +117361,6 @@
                       "kind": "TypeNominal",
                       "name": "Paren",
                       "printedName": "(Unicode.Scalar)",
-                      "usr": "s:s7UnicodeO6ScalarV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -105406,7 +117368,8 @@
                           "printedName": "Unicode.Scalar",
                           "usr": "s:s7UnicodeO6ScalarV"
                         }
-                      ]
+                      ],
+                      "usr": "s:s7UnicodeO6ScalarV"
                     }
                   ]
                 },
@@ -105432,16 +117395,16 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s21UnicodeDecodingResultO11scalarValueyABs0A0O6ScalarVcABmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 0
         },
         {
           "kind": "Var",
           "name": "emptyInput",
           "printedName": "emptyInput",
-          "declKind": "EnumElement",
-          "usr": "s:s21UnicodeDecodingResultO10emptyInputyA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -105476,16 +117439,16 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s21UnicodeDecodingResultO10emptyInputyA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 1
         },
         {
           "kind": "Var",
           "name": "error",
           "printedName": "error",
-          "declKind": "EnumElement",
-          "usr": "s:s21UnicodeDecodingResultO5erroryA2BmF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeFunc",
@@ -105520,50 +117483,81 @@
                 }
               ]
             }
+          ],
+          "declKind": "EnumElement",
+          "usr": "s:s21UnicodeDecodingResultO5erroryA2BmF",
+          "moduleName": "Swift",
+          "fixedbinaryorder": 2
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnicodeDecodingResult",
+              "printedName": "UnicodeDecodingResult",
+              "usr": "s:s21UnicodeDecodingResultO"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "UnicodeDecodingResult",
+              "printedName": "UnicodeDecodingResult",
+              "usr": "s:s21UnicodeDecodingResultO"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s21UnicodeDecodingResultO2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s21UnicodeDecodingResultO",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Frozen"
+      ],
+      "conformingProtocols": [
+        "Equatable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "UnicodeCodec",
       "printedName": "UnicodeCodec",
-      "declKind": "Protocol",
-      "usr": "s:s12UnicodeCodecP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : _UnicodeEncoding>",
-      "conformingProtocols": [
-        "_UnicodeEncoding"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init()",
-          "declKind": "Constructor",
-          "usr": "s:s12UnicodeCodecPxycfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnicodeCodec>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Self"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s12UnicodeCodecPxycfc",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnicodeCodec>",
+          "protocolReq": true
         },
         {
           "kind": "Function",
           "name": "decode",
           "printedName": "decode(_:)",
-          "declKind": "Func",
-          "usr": "s:s12UnicodeCodecP6decodeys0A14DecodingResultOqd__zStRd__7ElementQyd__8CodeUnitRtzlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self, I where Self : UnicodeCodec, I : IteratorProtocol, Self.CodeUnit == I.Element>",
-          "mutating": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -105576,18 +117570,18 @@
               "name": "GenericTypeParam",
               "printedName": "I"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s12UnicodeCodecP6decodeys0A14DecodingResultOqd__zStRd__7ElementQyd__8CodeUnitRtzlF",
+          "moduleName": "Swift",
+          "genericSig": "<Self, I where Self : UnicodeCodec, I : IteratorProtocol, Self.CodeUnit == I.Element>",
+          "protocolReq": true,
+          "mutating": true
         },
         {
           "kind": "Function",
           "name": "encode",
           "printedName": "encode(_:into:)",
-          "declKind": "Func",
-          "usr": "s:s12UnicodeCodecP6encode_4intoys0A0O6ScalarV_y8CodeUnitQzXEtFZ",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : UnicodeCodec>",
-          "static": true,
           "children": [
             {
               "kind": "TypeNominal",
@@ -105604,9 +117598,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.CodeUnit) -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -105632,25 +117623,32 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s12UnicodeCodecP6encode_4intoys0A0O6ScalarV_y8CodeUnitQzXEtFZ",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : UnicodeCodec>",
+          "static": true,
+          "protocolReq": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s12UnicodeCodecP",
+      "moduleName": "Swift",
+      "genericSig": "<Self : _UnicodeEncoding>",
+      "conformingProtocols": [
+        "_UnicodeEncoding"
       ]
     },
     {
       "kind": "Function",
       "name": "transcode",
       "printedName": "transcode(_:from:to:stoppingOnError:into:)",
-      "declKind": "Func",
-      "usr": "s:s9transcode_4from2to15stoppingOnError4intoSbx_q_mq0_mSby8CodeUnitQy0_XEtStRzs16_UnicodeEncodingR_sAHR0_AFQy_7ElementRtzr1_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Input, InputEncoding, OutputEncoding where Input : IteratorProtocol, InputEncoding : _UnicodeEncoding, OutputEncoding : _UnicodeEncoding, Input.Element == InputEncoding.CodeUnit>",
-      "declAttributes": [
-        "Inline",
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -105697,9 +117695,6 @@
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "(OutputEncoding.CodeUnit) -> Void",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -105725,45 +117720,35 @@
                 }
               ]
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s9transcode_4from2to15stoppingOnError4intoSbx_q_mq0_mSby8CodeUnitQy0_XEtStRzs16_UnicodeEncodingR_sAHR0_AFQy_7ElementRtzr1_lF",
+      "moduleName": "Swift",
+      "genericSig": "<Input, InputEncoding, OutputEncoding where Input : IteratorProtocol, InputEncoding : _UnicodeEncoding, OutputEncoding : _UnicodeEncoding, Input.Element == InputEncoding.CodeUnit>",
+      "declAttributes": [
+        "Inline",
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Unicode",
       "printedName": "Unicode",
-      "declKind": "Enum",
-      "usr": "s:s7UnicodeO",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Frozen"
-      ],
       "children": [
         {
           "kind": "TypeDecl",
           "name": "ASCII",
           "printedName": "ASCII",
-          "declKind": "Enum",
-          "usr": "s:s7UnicodeO5ASCIIO",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "_UnicodeEncoding"
-          ],
-          "declAttributes": [
-            "Frozen"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "CodeUnit",
               "printedName": "CodeUnit",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5ASCIIO8CodeUnita",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -105771,22 +117756,20 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s7UnicodeO5ASCIIO8CodeUnita",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "EncodedScalar",
               "printedName": "EncodedScalar",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5ASCIIO13EncodedScalara",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "CollectionOfOne",
                   "printedName": "CollectionOfOne<Unicode.ASCII.CodeUnit>",
-                  "usr": "s:s15CollectionOfOneV",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -105801,22 +117784,18 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:s15CollectionOfOneV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s7UnicodeO5ASCIIO13EncodedScalara",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "encodedReplacementCharacter",
               "printedName": "encodedReplacementCharacter",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO5ASCIIO27encodedReplacementCharacters15CollectionOfOneVys5UInt8VGvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -105827,7 +117806,6 @@
                       "kind": "TypeNominal",
                       "name": "CollectionOfOne",
                       "printedName": "CollectionOfOne<UInt8>",
-                      "usr": "s:s15CollectionOfOneV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -105835,7 +117813,8 @@
                           "printedName": "UInt8",
                           "usr": "s:s5UInt8V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s15CollectionOfOneV"
                     }
                   ]
                 },
@@ -105843,11 +117822,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO5ASCIIO27encodedReplacementCharacters15CollectionOfOneVys5UInt8VGvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -105858,7 +117832,6 @@
                           "kind": "TypeNominal",
                           "name": "CollectionOfOne",
                           "printedName": "CollectionOfOne<UInt8>",
-                          "usr": "s:s15CollectionOfOneV",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -105866,27 +117839,30 @@
                               "printedName": "UInt8",
                               "usr": "s:s5UInt8V"
                             }
-                          ]
+                          ],
+                          "usr": "s:s15CollectionOfOneV"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO5ASCIIO27encodedReplacementCharacters15CollectionOfOneVys5UInt8VGvgZ",
+                  "moduleName": "Swift",
+                  "static": true
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO5ASCIIO27encodedReplacementCharacters15CollectionOfOneVys5UInt8VGvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "decode",
               "printedName": "decode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5ASCIIO6decodeyAB6ScalarVs15CollectionOfOneVys5UInt8VGFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable",
-                "Inline"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -105903,7 +117879,6 @@
                       "kind": "TypeNominal",
                       "name": "CollectionOfOne",
                       "printedName": "CollectionOfOne<UInt8>",
-                      "usr": "s:s15CollectionOfOneV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -105911,31 +117886,30 @@
                           "printedName": "UInt8",
                           "usr": "s:s5UInt8V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s15CollectionOfOneV"
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5ASCIIO6decodeyAB6ScalarVs15CollectionOfOneVys5UInt8VGFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable",
+                "Inline"
               ]
             },
             {
               "kind": "Function",
               "name": "encode",
               "printedName": "encode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5ASCIIO6encodeys15CollectionOfOneVys5UInt8VGSgAB6ScalarVFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable",
-                "Inline"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Unicode.ASCII.EncodedScalar?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -105946,7 +117920,6 @@
                           "kind": "TypeNominal",
                           "name": "CollectionOfOne",
                           "printedName": "CollectionOfOne<UInt8>",
-                          "usr": "s:s15CollectionOfOneV",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -105954,11 +117927,13 @@
                               "printedName": "UInt8",
                               "usr": "s:s5UInt8V"
                             }
-                          ]
+                          ],
+                          "usr": "s:s15CollectionOfOneV"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -105966,28 +117941,25 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5ASCIIO6encodeys15CollectionOfOneVys5UInt8VGSgAB6ScalarVFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable",
+                "Inline"
               ]
             },
             {
               "kind": "Function",
               "name": "transcode",
               "printedName": "transcode(_:from:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5ASCIIO9transcode_4froms15CollectionOfOneVys5UInt8VGSg13EncodedScalarQz_xmts01_A8EncodingRzlFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<FromEncoding where FromEncoding : _UnicodeEncoding>",
-              "static": true,
-              "declAttributes": [
-                "Inlinable",
-                "Inline"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Unicode.ASCII.EncodedScalar?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -105998,7 +117970,6 @@
                           "kind": "TypeNominal",
                           "name": "CollectionOfOne",
                           "printedName": "CollectionOfOne<UInt8>",
-                          "usr": "s:s15CollectionOfOneV",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -106006,11 +117977,13 @@
                               "printedName": "UInt8",
                               "usr": "s:s5UInt8V"
                             }
-                          ]
+                          ],
+                          "usr": "s:s15CollectionOfOneV"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -106029,34 +118002,26 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5ASCIIO9transcode_4froms15CollectionOfOneVys5UInt8VGSg13EncodedScalarQz_xmts01_A8EncodingRzlFZ",
+              "moduleName": "Swift",
+              "genericSig": "<FromEncoding where FromEncoding : _UnicodeEncoding>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable",
+                "Inline"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "Parser",
               "printedName": "Parser",
-              "declKind": "Struct",
-              "usr": "s:s7UnicodeO5ASCIIO6ParserV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "_UnicodeParser"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
               "children": [
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init()",
-                  "declKind": "Constructor",
-                  "usr": "s:s7UnicodeO5ASCIIO6ParserVAFycfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106064,16 +118029,18 @@
                       "printedName": "Unicode.ASCII.Parser",
                       "usr": "s:s7UnicodeO5ASCIIO6ParserV"
                     }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:s7UnicodeO5ASCIIO6ParserVAFycfc",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
                   "kind": "TypeAlias",
                   "name": "Encoding",
                   "printedName": "Encoding",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO5ASCIIO6ParserV8Encodinga",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106081,27 +118048,20 @@
                       "printedName": "Unicode.ASCII",
                       "usr": "s:s7UnicodeO5ASCIIO"
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:s7UnicodeO5ASCIIO6ParserV8Encodinga",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Function",
                   "name": "parseScalar",
                   "printedName": "parseScalar(from:)",
-                  "declKind": "Func",
-                  "usr": "s:s7UnicodeO5ASCIIO6ParserV11parseScalar4fromAB11ParseResultOy_s15CollectionOfOneVys5UInt8VGGxz_tStRzAN7ElementRtzlF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<I where I : IteratorProtocol, I.Element == Unicode.ASCII.Parser.Encoding.CodeUnit>",
-                  "mutating": true,
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "ParseResult",
                       "printedName": "Unicode.ParseResult<Unicode.ASCII.Parser.Encoding.EncodedScalar>",
-                      "usr": "s:s7UnicodeO11ParseResultO",
                       "children": [
                         {
                           "kind": "TypeNameAlias",
@@ -106112,7 +118072,6 @@
                               "kind": "TypeNominal",
                               "name": "CollectionOfOne",
                               "printedName": "CollectionOfOne<UInt8>",
-                              "usr": "s:s15CollectionOfOneV",
                               "children": [
                                 {
                                   "kind": "TypeNominal",
@@ -106120,29 +118079,44 @@
                                   "printedName": "UInt8",
                                   "usr": "s:s5UInt8V"
                                 }
-                              ]
+                              ],
+                              "usr": "s:s15CollectionOfOneV"
                             }
                           ]
                         }
-                      ]
+                      ],
+                      "usr": "s:s7UnicodeO11ParseResultO"
                     },
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "I"
                     }
-                  ]
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:s7UnicodeO5ASCIIO6ParserV11parseScalar4fromAB11ParseResultOy_s15CollectionOfOneVys5UInt8VGGxz_tStRzAN7ElementRtzlF",
+                  "moduleName": "Swift",
+                  "genericSig": "<I where I : IteratorProtocol, I.Element == Unicode.ASCII.Parser.Encoding.CodeUnit>",
+                  "declAttributes": [
+                    "Inlinable"
+                  ],
+                  "mutating": true
                 }
+              ],
+              "declKind": "Struct",
+              "usr": "s:s7UnicodeO5ASCIIO6ParserV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "_UnicodeParser"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "ForwardParser",
               "printedName": "ForwardParser",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5ASCIIO13ForwardParsera",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106150,16 +118124,15 @@
                   "printedName": "Unicode.ASCII.Parser",
                   "usr": "s:s7UnicodeO5ASCIIO6ParserV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s7UnicodeO5ASCIIO13ForwardParsera",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "ReverseParser",
               "printedName": "ReverseParser",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5ASCIIO13ReverseParsera",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106167,18 +118140,26 @@
                   "printedName": "Unicode.ASCII.Parser",
                   "usr": "s:s7UnicodeO5ASCIIO6ParserV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s7UnicodeO5ASCIIO13ReverseParsera",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Enum",
+          "usr": "s:s7UnicodeO5ASCIIO",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Frozen"
+          ],
+          "conformingProtocols": [
+            "_UnicodeEncoding"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Encoding",
           "printedName": "Encoding",
-          "declKind": "TypeAlias",
-          "usr": "s:s7UnicodeO8Encodinga",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -106186,16 +118167,15 @@
               "printedName": "_UnicodeEncoding",
               "usr": "s:s16_UnicodeEncodingP"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s7UnicodeO8Encodinga",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "Parser",
           "printedName": "Parser",
-          "declKind": "TypeAlias",
-          "usr": "s:s7UnicodeO6Parsera",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -106203,44 +118183,20 @@
               "printedName": "_UnicodeParser",
               "usr": "s:s14_UnicodeParserP"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s7UnicodeO6Parsera",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeDecl",
           "name": "Scalar",
           "printedName": "Scalar",
-          "declKind": "Struct",
-          "usr": "s:s7UnicodeO6ScalarV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "_ExpressibleByBuiltinUnicodeScalarLiteral",
-            "ExpressibleByUnicodeScalarLiteral",
-            "CustomStringConvertible",
-            "CustomDebugStringConvertible",
-            "LosslessStringConvertible",
-            "Hashable",
-            "Equatable",
-            "Comparable",
-            "CustomReflectable",
-            "_CustomPlaygroundQuickLookable",
-            "TextOutputStreamable"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "value",
               "printedName": "value",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV5values6UInt32Vvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106252,10 +118208,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV5values6UInt32Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106263,21 +118215,23 @@
                       "printedName": "UInt32",
                       "usr": "s:s6UInt32V"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV5values6UInt32Vvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV5values6UInt32Vvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(unicodeScalarLiteral:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO6ScalarV07unicodeB7LiteralA2D_tcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Transparent"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106291,25 +118245,23 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO6ScalarV07unicodeB7LiteralA2D_tcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Transparent"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO6ScalarVyADSgs6UInt32Vcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Unicode.Scalar?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106317,7 +118269,8 @@
                       "printedName": "Unicode.Scalar",
                       "usr": "s:s7UnicodeO6ScalarV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -106325,25 +118278,23 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO6ScalarVyADSgs6UInt32Vcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO6ScalarVyADSgs6UInt16Vcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Unicode.Scalar?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106351,7 +118302,8 @@
                       "printedName": "Unicode.Scalar",
                       "usr": "s:s7UnicodeO6ScalarV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -106359,19 +118311,18 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO6ScalarVyADSgs6UInt16Vcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO6ScalarVyADs5UInt8Vcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106385,19 +118336,18 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO6ScalarVyADs5UInt8Vcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO6ScalarVyA2Dcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106411,19 +118361,18 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO6ScalarVyA2Dcfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "escaped",
               "printedName": "escaped(asASCII:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO6ScalarV7escaped7asASCIISSSb_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106437,19 +118386,18 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO6ScalarV7escaped7asASCIISSSb_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "isASCII",
               "printedName": "isASCII",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV7isASCIISbvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106461,10 +118409,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV7isASCIISbvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106472,18 +118416,23 @@
                       "printedName": "Bool",
                       "usr": "s:Sb"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV7isASCIISbvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV7isASCIISbvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "UnicodeScalarLiteralType",
               "printedName": "UnicodeScalarLiteralType",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO6ScalarV0aB11LiteralTypea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106491,19 +118440,16 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s7UnicodeO6ScalarV0aB11LiteralTypea",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Var",
               "name": "description",
               "printedName": "description",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV11descriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106515,10 +118461,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV11descriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106526,18 +118468,23 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV11descriptionSSvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV11descriptionSSvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "debugDescription",
               "printedName": "debugDescription",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV16debugDescriptionSSvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106549,10 +118496,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV16debugDescriptionSSvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106560,27 +118503,25 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV16debugDescriptionSSvg",
+                  "moduleName": "Swift"
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV16debugDescriptionSSvp",
+              "moduleName": "Swift"
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO6ScalarVyADSgSScfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Unicode.Scalar?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106588,7 +118529,8 @@
                       "printedName": "Unicode.Scalar",
                       "usr": "s:s7UnicodeO6ScalarV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -106596,19 +118538,18 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO6ScalarVyADSgSScfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO6ScalarV4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106621,16 +118562,18 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO6ScalarV4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106642,10 +118585,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106653,27 +118592,27 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV9hashValueSivg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO6ScalarVyADSgSicfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Unicode.Scalar?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106681,7 +118620,8 @@
                       "printedName": "Unicode.Scalar",
                       "usr": "s:s7UnicodeO6ScalarV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -106689,37 +118629,87 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO6ScalarVyADSgSicfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Scalar",
+                  "printedName": "Unicode.Scalar",
+                  "usr": "s:s7UnicodeO6ScalarV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Scalar",
+                  "printedName": "Unicode.Scalar",
+                  "usr": "s:s7UnicodeO6ScalarV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO6ScalarV2eeoiySbAD_ADtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
+              ]
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Scalar",
+                  "printedName": "Unicode.Scalar",
+                  "usr": "s:s7UnicodeO6ScalarV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "Scalar",
+                  "printedName": "Unicode.Scalar",
+                  "usr": "s:s7UnicodeO6ScalarV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO6ScalarV1loiySbAD_ADtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "UTF16View",
               "printedName": "UTF16View",
-              "declKind": "Struct",
-              "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "RandomAccessCollection",
-                "BidirectionalCollection",
-                "Collection",
-                "Sequence"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
               "children": [
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init(value:)",
-                  "declKind": "Constructor",
-                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV5valueAfD_tcfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106733,22 +118723,24 @@
                       "printedName": "Unicode.Scalar",
                       "usr": "s:s7UnicodeO6ScalarV"
                     }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV5valueAfD_tcfc",
+                  "moduleName": "Swift",
+                  "isInternal": true,
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
                   "kind": "TypeAlias",
                   "name": "Indices",
                   "printedName": "Indices",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV7Indicesa",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Range",
                       "printedName": "Range<Int>",
-                      "usr": "s:Sn",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -106756,21 +118748,18 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sn"
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV7Indicesa",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "startIndex",
                   "printedName": "startIndex",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV10startIndexSivp",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106782,10 +118771,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV10startIndexSivg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -106793,21 +118778,23 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV10startIndexSivg",
+                      "moduleName": "Swift"
                     }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV10startIndexSivp",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
                   "kind": "Var",
                   "name": "endIndex",
                   "printedName": "endIndex",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV8endIndexSivp",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106819,10 +118806,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV8endIndexSivg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -106830,18 +118813,55 @@
                           "printedName": "Int",
                           "usr": "s:Si"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV8endIndexSivg",
+                      "moduleName": "Swift"
                     }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV8endIndexSivp",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
+                  ]
+                },
+                {
+                  "kind": "Subscript",
+                  "name": "subscript",
+                  "printedName": "subscript(_:)",
+                  "children": [
+                    {
+                      "kind": "TypeNameAlias",
+                      "name": "CodeUnit",
+                      "printedName": "UTF16.CodeUnit",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "UInt16",
+                          "printedName": "UInt16",
+                          "usr": "s:s6UInt16V"
+                        }
+                      ]
+                    },
+                    {
+                      "kind": "TypeNominal",
+                      "name": "Int",
+                      "printedName": "Int",
+                      "usr": "s:Si"
+                    }
+                  ],
+                  "declKind": "Subscript",
+                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewVys6UInt16VSicip",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
                   "kind": "TypeAlias",
                   "name": "Element",
                   "printedName": "Element",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV7Elementa",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -106856,16 +118876,16 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV7Elementa",
+                  "moduleName": "Swift",
+                  "implicit": true
                 },
                 {
                   "kind": "TypeAlias",
                   "name": "Index",
                   "printedName": "Index",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV5Indexa",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106873,22 +118893,21 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV5Indexa",
+                  "moduleName": "Swift",
+                  "implicit": true
                 },
                 {
                   "kind": "TypeAlias",
                   "name": "SubSequence",
                   "printedName": "SubSequence",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV11SubSequencea",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Slice",
                       "printedName": "Slice<Unicode.Scalar.UTF16View>",
-                      "usr": "s:s5SliceV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -106896,24 +118915,24 @@
                           "printedName": "Unicode.Scalar.UTF16View",
                           "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV"
                         }
-                      ]
+                      ],
+                      "usr": "s:s5SliceV"
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV11SubSequencea",
+                  "moduleName": "Swift",
+                  "implicit": true
                 },
                 {
                   "kind": "TypeAlias",
                   "name": "Iterator",
                   "printedName": "Iterator",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV8Iteratora",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "IndexingIterator",
                       "printedName": "IndexingIterator<Unicode.Scalar.UTF16View>",
-                      "usr": "s:s16IndexingIteratorV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -106921,23 +118940,33 @@
                           "printedName": "Unicode.Scalar.UTF16View",
                           "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV"
                         }
-                      ]
+                      ],
+                      "usr": "s:s16IndexingIteratorV"
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV8Iteratora",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
+              ],
+              "declKind": "Struct",
+              "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "RandomAccessCollection",
+                "BidirectionalCollection",
+                "Collection",
+                "Sequence"
               ]
             },
             {
               "kind": "Var",
               "name": "utf16",
               "printedName": "utf16",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV5utf16AD9UTF16ViewVvp",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106949,10 +118978,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV5utf16AD9UTF16ViewVvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106960,18 +118985,23 @@
                       "printedName": "Unicode.Scalar.UTF16View",
                       "usr": "s:s7UnicodeO6ScalarV9UTF16ViewV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV5utf16AD9UTF16ViewVvg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV5utf16AD9UTF16ViewVvp",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Var",
               "name": "customMirror",
               "printedName": "customMirror",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV12customMirrors0D0Vvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -106983,10 +119013,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV12customMirrors0D0Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -106994,23 +119020,20 @@
                       "printedName": "Mirror",
                       "usr": "s:s6MirrorV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV12customMirrors0D0Vvg",
+                  "moduleName": "Swift"
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV12customMirrors0D0Vvp",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "customPlaygroundQuickLook",
               "printedName": "customPlaygroundQuickLook",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV25customPlaygroundQuickLooks01_deF0Ovp",
-              "location": "",
-              "moduleName": "Swift",
-              "deprecated": true,
-              "declAttributes": [
-                "Available",
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -107022,10 +119045,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV25customPlaygroundQuickLooks01_deF0Ovg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107033,22 +119052,24 @@
                       "printedName": "_PlaygroundQuickLook",
                       "usr": "s:s20_PlaygroundQuickLookO"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV25customPlaygroundQuickLooks01_deF0Ovg",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV25customPlaygroundQuickLooks01_deF0Ovp",
+              "moduleName": "Swift",
+              "deprecated": true,
+              "declAttributes": [
+                "Available"
               ]
             },
             {
               "kind": "Function",
               "name": "write",
               "printedName": "write(to:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO6ScalarV5write2toyxz_ts16TextOutputStreamRzlF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Target where Target : TextOutputStream>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -107060,25 +119081,24 @@
                   "name": "GenericTypeParam",
                   "printedName": "Target"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO6ScalarV5write2toyxz_ts16TextOutputStreamRzlF",
+              "moduleName": "Swift",
+              "genericSig": "<Target where Target : TextOutputStream>",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "Properties",
               "printedName": "Properties",
-              "declKind": "Struct",
-              "usr": "s:s7UnicodeO6ScalarV10PropertiesV",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init(_:)",
-                  "declKind": "Constructor",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesVyAfDcfc",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107092,16 +119112,16 @@
                       "printedName": "Unicode.Scalar",
                       "usr": "s:s7UnicodeO6ScalarV"
                     }
-                  ]
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesVyAfDcfc",
+                  "moduleName": "Swift",
+                  "isInternal": true
                 },
                 {
                   "kind": "Var",
                   "name": "isAlphabetic",
                   "printedName": "isAlphabetic",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isAlphabeticSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107113,10 +119133,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isAlphabeticSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107124,18 +119140,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isAlphabeticSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isAlphabeticSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isASCIIHexDigit",
                   "printedName": "isASCIIHexDigit",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isASCIIHexDigitSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107147,10 +119165,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isASCIIHexDigitSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107158,18 +119172,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isASCIIHexDigitSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isASCIIHexDigitSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isBidiControl",
                   "printedName": "isBidiControl",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isBidiControlSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107181,10 +119197,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isBidiControlSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107192,18 +119204,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isBidiControlSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isBidiControlSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isBidiMirrored",
                   "printedName": "isBidiMirrored",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV14isBidiMirroredSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107215,10 +119229,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV14isBidiMirroredSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107226,18 +119236,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV14isBidiMirroredSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV14isBidiMirroredSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isDash",
                   "printedName": "isDash",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV6isDashSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107249,10 +119261,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV6isDashSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107260,18 +119268,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV6isDashSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV6isDashSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isDefaultIgnorableCodePoint",
                   "printedName": "isDefaultIgnorableCodePoint",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV27isDefaultIgnorableCodePointSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107283,10 +119293,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV27isDefaultIgnorableCodePointSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107294,18 +119300,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV27isDefaultIgnorableCodePointSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV27isDefaultIgnorableCodePointSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isDeprecated",
                   "printedName": "isDeprecated",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isDeprecatedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107317,10 +119325,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isDeprecatedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107328,18 +119332,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isDeprecatedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isDeprecatedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isDiacritic",
                   "printedName": "isDiacritic",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isDiacriticSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107351,10 +119357,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isDiacriticSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107362,18 +119364,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isDiacriticSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isDiacriticSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isExtender",
                   "printedName": "isExtender",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isExtenderSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107385,10 +119389,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isExtenderSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107396,18 +119396,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isExtenderSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isExtenderSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isFullCompositionExclusion",
                   "printedName": "isFullCompositionExclusion",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV26isFullCompositionExclusionSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107419,10 +119421,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV26isFullCompositionExclusionSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107430,18 +119428,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV26isFullCompositionExclusionSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV26isFullCompositionExclusionSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isGraphemeBase",
                   "printedName": "isGraphemeBase",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV14isGraphemeBaseSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107453,10 +119453,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV14isGraphemeBaseSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107464,18 +119460,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV14isGraphemeBaseSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV14isGraphemeBaseSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isGraphemeExtend",
                   "printedName": "isGraphemeExtend",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV16isGraphemeExtendSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107487,10 +119485,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV16isGraphemeExtendSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107498,18 +119492,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV16isGraphemeExtendSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV16isGraphemeExtendSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isHexDigit",
                   "printedName": "isHexDigit",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isHexDigitSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107521,10 +119517,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isHexDigitSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107532,18 +119524,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isHexDigitSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isHexDigitSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isIDContinue",
                   "printedName": "isIDContinue",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isIDContinueSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107555,10 +119549,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isIDContinueSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107566,18 +119556,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isIDContinueSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isIDContinueSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isIDStart",
                   "printedName": "isIDStart",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV9isIDStartSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107589,10 +119581,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV9isIDStartSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107600,18 +119588,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV9isIDStartSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV9isIDStartSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isIdeographic",
                   "printedName": "isIdeographic",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isIdeographicSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107623,10 +119613,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isIdeographicSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107634,18 +119620,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isIdeographicSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isIdeographicSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isIDSBinaryOperator",
                   "printedName": "isIDSBinaryOperator",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isIDSBinaryOperatorSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107657,10 +119645,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isIDSBinaryOperatorSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107668,18 +119652,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isIDSBinaryOperatorSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isIDSBinaryOperatorSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isIDSTrinaryOperator",
                   "printedName": "isIDSTrinaryOperator",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV20isIDSTrinaryOperatorSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107691,10 +119677,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV20isIDSTrinaryOperatorSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107702,18 +119684,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV20isIDSTrinaryOperatorSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV20isIDSTrinaryOperatorSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isJoinControl",
                   "printedName": "isJoinControl",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isJoinControlSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107725,10 +119709,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isJoinControlSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107736,18 +119716,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isJoinControlSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isJoinControlSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isLogicalOrderException",
                   "printedName": "isLogicalOrderException",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV23isLogicalOrderExceptionSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107759,10 +119741,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV23isLogicalOrderExceptionSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107770,18 +119748,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV23isLogicalOrderExceptionSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV23isLogicalOrderExceptionSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isLowercase",
                   "printedName": "isLowercase",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isLowercaseSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107793,10 +119773,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isLowercaseSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107804,18 +119780,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isLowercaseSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isLowercaseSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isMath",
                   "printedName": "isMath",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV6isMathSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107827,10 +119805,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV6isMathSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107838,18 +119812,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV6isMathSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV6isMathSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isNoncharacterCodePoint",
                   "printedName": "isNoncharacterCodePoint",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV23isNoncharacterCodePointSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107861,10 +119837,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV23isNoncharacterCodePointSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107872,18 +119844,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV23isNoncharacterCodePointSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV23isNoncharacterCodePointSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isQuotationMark",
                   "printedName": "isQuotationMark",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isQuotationMarkSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107895,10 +119869,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isQuotationMarkSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107906,18 +119876,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isQuotationMarkSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isQuotationMarkSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isRadical",
                   "printedName": "isRadical",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV9isRadicalSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107929,10 +119901,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV9isRadicalSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107940,18 +119908,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV9isRadicalSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV9isRadicalSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isSoftDotted",
                   "printedName": "isSoftDotted",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isSoftDottedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107963,10 +119933,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isSoftDottedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -107974,18 +119940,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isSoftDottedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isSoftDottedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isTerminalPunctuation",
                   "printedName": "isTerminalPunctuation",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21isTerminalPunctuationSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -107997,10 +119965,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21isTerminalPunctuationSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108008,18 +119972,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21isTerminalPunctuationSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21isTerminalPunctuationSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isUnifiedIdeograph",
                   "printedName": "isUnifiedIdeograph",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV18isUnifiedIdeographSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108031,10 +119997,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV18isUnifiedIdeographSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108042,18 +120004,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV18isUnifiedIdeographSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV18isUnifiedIdeographSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isUppercase",
                   "printedName": "isUppercase",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isUppercaseSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108065,10 +120029,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isUppercaseSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108076,18 +120036,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isUppercaseSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV11isUppercaseSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isWhitespace",
                   "printedName": "isWhitespace",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isWhitespaceSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108099,10 +120061,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isWhitespaceSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108110,18 +120068,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isWhitespaceSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12isWhitespaceSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isXIDContinue",
                   "printedName": "isXIDContinue",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isXIDContinueSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108133,10 +120093,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isXIDContinueSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108144,18 +120100,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isXIDContinueSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV13isXIDContinueSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isXIDStart",
                   "printedName": "isXIDStart",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isXIDStartSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108167,10 +120125,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isXIDStartSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108178,18 +120132,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isXIDStartSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV10isXIDStartSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isSentenceTerminal",
                   "printedName": "isSentenceTerminal",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV18isSentenceTerminalSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108201,10 +120157,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV18isSentenceTerminalSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108212,18 +120164,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV18isSentenceTerminalSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV18isSentenceTerminalSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isVariationSelector",
                   "printedName": "isVariationSelector",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isVariationSelectorSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108235,10 +120189,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isVariationSelectorSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108246,18 +120196,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isVariationSelectorSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isVariationSelectorSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isPatternSyntax",
                   "printedName": "isPatternSyntax",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isPatternSyntaxSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108269,10 +120221,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isPatternSyntaxSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108280,18 +120228,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isPatternSyntaxSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isPatternSyntaxSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isPatternWhitespace",
                   "printedName": "isPatternWhitespace",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isPatternWhitespaceSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108303,10 +120253,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isPatternWhitespaceSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108314,18 +120260,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isPatternWhitespaceSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isPatternWhitespaceSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isCased",
                   "printedName": "isCased",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV7isCasedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108337,10 +120285,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV7isCasedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108348,18 +120292,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV7isCasedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV7isCasedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isCaseIgnorable",
                   "printedName": "isCaseIgnorable",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isCaseIgnorableSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108371,10 +120317,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isCaseIgnorableSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108382,18 +120324,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isCaseIgnorableSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isCaseIgnorableSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "changesWhenLowercased",
                   "printedName": "changesWhenLowercased",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenLowercasedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108405,10 +120349,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenLowercasedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108416,18 +120356,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenLowercasedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenLowercasedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "changesWhenUppercased",
                   "printedName": "changesWhenUppercased",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenUppercasedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108439,10 +120381,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenUppercasedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108450,18 +120388,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenUppercasedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenUppercasedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "changesWhenTitlecased",
                   "printedName": "changesWhenTitlecased",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenTitlecasedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108473,10 +120413,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenTitlecasedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108484,18 +120420,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenTitlecasedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenTitlecasedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "changesWhenCaseFolded",
                   "printedName": "changesWhenCaseFolded",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenCaseFoldedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108507,10 +120445,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenCaseFoldedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108518,18 +120452,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenCaseFoldedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenCaseFoldedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "changesWhenCaseMapped",
                   "printedName": "changesWhenCaseMapped",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenCaseMappedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108541,10 +120477,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenCaseMappedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108552,18 +120484,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenCaseMappedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV21changesWhenCaseMappedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "changesWhenNFKCCaseFolded",
                   "printedName": "changesWhenNFKCCaseFolded",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV25changesWhenNFKCCaseFoldedSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108575,10 +120509,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV25changesWhenNFKCCaseFoldedSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108586,18 +120516,20 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV25changesWhenNFKCCaseFoldedSbvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV25changesWhenNFKCCaseFoldedSbvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "isEmoji",
                   "printedName": "isEmoji",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV7isEmojiSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108609,10 +120541,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV7isEmojiSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108620,18 +120548,26 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV7isEmojiSbvg",
+                      "moduleName": "Swift"
                     }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV7isEmojiSbvp",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Available",
+                    "Available",
+                    "Available",
+                    "Available"
                   ]
                 },
                 {
                   "kind": "Var",
                   "name": "isEmojiPresentation",
                   "printedName": "isEmojiPresentation",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isEmojiPresentationSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108643,10 +120579,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isEmojiPresentationSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108654,18 +120586,26 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isEmojiPresentationSbvg",
+                      "moduleName": "Swift"
                     }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isEmojiPresentationSbvp",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Available",
+                    "Available",
+                    "Available",
+                    "Available"
                   ]
                 },
                 {
                   "kind": "Var",
                   "name": "isEmojiModifier",
                   "printedName": "isEmojiModifier",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isEmojiModifierSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108677,10 +120617,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isEmojiModifierSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108688,18 +120624,26 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isEmojiModifierSbvg",
+                      "moduleName": "Swift"
                     }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15isEmojiModifierSbvp",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Available",
+                    "Available",
+                    "Available",
+                    "Available"
                   ]
                 },
                 {
                   "kind": "Var",
                   "name": "isEmojiModifierBase",
                   "printedName": "isEmojiModifierBase",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isEmojiModifierBaseSbvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108711,10 +120655,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isEmojiModifierBaseSbvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108722,18 +120662,26 @@
                           "printedName": "Bool",
                           "usr": "s:Sb"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isEmojiModifierBaseSbvg",
+                      "moduleName": "Swift"
                     }
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV19isEmojiModifierBaseSbvp",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Available",
+                    "Available",
+                    "Available",
+                    "Available"
                   ]
                 },
                 {
                   "kind": "Var",
                   "name": "lowercaseMapping",
                   "printedName": "lowercaseMapping",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV16lowercaseMappingSSvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108745,10 +120693,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV16lowercaseMappingSSvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108756,18 +120700,20 @@
                           "printedName": "String",
                           "usr": "s:SS"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV16lowercaseMappingSSvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV16lowercaseMappingSSvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "titlecaseMapping",
                   "printedName": "titlecaseMapping",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV16titlecaseMappingSSvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108779,10 +120725,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV16titlecaseMappingSSvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108790,18 +120732,20 @@
                           "printedName": "String",
                           "usr": "s:SS"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV16titlecaseMappingSSvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV16titlecaseMappingSSvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "uppercaseMapping",
                   "printedName": "uppercaseMapping",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV16uppercaseMappingSSvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108813,10 +120757,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV16uppercaseMappingSSvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108824,24 +120764,25 @@
                           "printedName": "String",
                           "usr": "s:SS"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV16uppercaseMappingSSvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV16uppercaseMappingSSvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "age",
                   "printedName": "age",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV3ageSi5major_Si5minortSgvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
                       "printedName": "Unicode.Version?",
-                      "usr": "s:Sq",
                       "children": [
                         {
                           "kind": "TypeNameAlias",
@@ -108869,22 +120810,18 @@
                             }
                           ]
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     },
                     {
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV3ageSi5major_Si5minortSgvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "Optional",
                           "printedName": "Unicode.Version?",
-                          "usr": "s:Sq",
                           "children": [
                             {
                               "kind": "TypeNameAlias",
@@ -108912,20 +120849,23 @@
                                 }
                               ]
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV3ageSi5major_Si5minortSgvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV3ageSi5major_Si5minortSgvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "generalCategory",
                   "printedName": "generalCategory",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15generalCategoryAB07GeneralE0Ovp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -108937,10 +120877,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15generalCategoryAB07GeneralE0Ovg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108948,24 +120884,25 @@
                           "printedName": "Unicode.GeneralCategory",
                           "usr": "s:s7UnicodeO15GeneralCategoryO"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV15generalCategoryAB07GeneralE0Ovg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV15generalCategoryAB07GeneralE0Ovp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "name",
                   "printedName": "name",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV4nameSSSgvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
                       "printedName": "String?",
-                      "usr": "s:Sq",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -108973,22 +120910,18 @@
                           "printedName": "String",
                           "usr": "s:SS"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     },
                     {
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV4nameSSSgvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "Optional",
                           "printedName": "String?",
-                          "usr": "s:Sq",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -108996,26 +120929,28 @@
                               "printedName": "String",
                               "usr": "s:SS"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV4nameSSSgvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV4nameSSSgvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "nameAlias",
                   "printedName": "nameAlias",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV9nameAliasSSSgvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
                       "printedName": "String?",
-                      "usr": "s:Sq",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -109023,22 +120958,18 @@
                           "printedName": "String",
                           "usr": "s:SS"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     },
                     {
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV9nameAliasSSSgvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "Optional",
                           "printedName": "String?",
-                          "usr": "s:Sq",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -109046,20 +120977,23 @@
                               "printedName": "String",
                               "usr": "s:SS"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV9nameAliasSSSgvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV9nameAliasSSSgvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "canonicalCombiningClass",
                   "printedName": "canonicalCombiningClass",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV23canonicalCombiningClassAB09CanonicaleF0Vvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -109071,10 +121005,6 @@
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV23canonicalCombiningClassAB09CanonicaleF0Vvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -109082,24 +121012,25 @@
                           "printedName": "Unicode.CanonicalCombiningClass",
                           "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV23canonicalCombiningClassAB09CanonicaleF0Vvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV23canonicalCombiningClassAB09CanonicaleF0Vvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "numericType",
                   "printedName": "numericType",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV11numericTypeAB07NumericE0OSgvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
                       "printedName": "Unicode.NumericType?",
-                      "usr": "s:Sq",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -109107,22 +121038,18 @@
                           "printedName": "Unicode.NumericType",
                           "usr": "s:s7UnicodeO11NumericTypeO"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     },
                     {
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV11numericTypeAB07NumericE0OSgvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "Optional",
                           "printedName": "Unicode.NumericType?",
-                          "usr": "s:Sq",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -109130,26 +121057,28 @@
                               "printedName": "Unicode.NumericType",
                               "usr": "s:s7UnicodeO11NumericTypeO"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV11numericTypeAB07NumericE0OSgvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV11numericTypeAB07NumericE0OSgvp",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Var",
                   "name": "numericValue",
                   "printedName": "numericValue",
-                  "declKind": "Var",
-                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12numericValueSdSgvp",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
                       "printedName": "Double?",
-                      "usr": "s:Sq",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -109157,22 +121086,18 @@
                           "printedName": "Double",
                           "usr": "s:Sd"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     },
                     {
                       "kind": "Getter",
                       "name": "_",
                       "printedName": "_()",
-                      "declKind": "Accessor",
-                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12numericValueSdSgvg",
-                      "location": "",
-                      "moduleName": "Swift",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "Optional",
                           "printedName": "Double?",
-                          "usr": "s:Sq",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -109180,22 +121105,28 @@
                               "printedName": "Double",
                               "usr": "s:Sd"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         }
-                      ]
+                      ],
+                      "declKind": "Accessor",
+                      "usr": "s:s7UnicodeO6ScalarV10PropertiesV12numericValueSdSgvg",
+                      "moduleName": "Swift"
                     }
-                  ]
+                  ],
+                  "declKind": "Var",
+                  "usr": "s:s7UnicodeO6ScalarV10PropertiesV12numericValueSdSgvp",
+                  "moduleName": "Swift"
                 }
-              ]
+              ],
+              "declKind": "Struct",
+              "usr": "s:s7UnicodeO6ScalarV10PropertiesV",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "properties",
               "printedName": "properties",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO6ScalarV10propertiesAD10PropertiesVvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -109207,10 +121138,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO6ScalarV10propertiesAD10PropertiesVvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -109218,36 +121145,46 @@
                       "printedName": "Unicode.Scalar.Properties",
                       "usr": "s:s7UnicodeO6ScalarV10PropertiesV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO6ScalarV10propertiesAD10PropertiesVvg",
+                  "moduleName": "Swift"
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO6ScalarV10propertiesAD10PropertiesVvp",
+              "moduleName": "Swift"
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s7UnicodeO6ScalarV",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "_ExpressibleByBuiltinUnicodeScalarLiteral",
+            "ExpressibleByUnicodeScalarLiteral",
+            "CustomStringConvertible",
+            "CustomDebugStringConvertible",
+            "LosslessStringConvertible",
+            "Hashable",
+            "Equatable",
+            "Comparable",
+            "CustomReflectable",
+            "_CustomPlaygroundQuickLookable",
+            "TextOutputStreamable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "UTF16",
           "printedName": "UTF16",
-          "declKind": "Enum",
-          "usr": "s:s7UnicodeO5UTF16O",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "_UnicodeEncoding",
-            "UnicodeCodec"
-          ],
-          "declAttributes": [
-            "Frozen"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "CodeUnit",
               "printedName": "CodeUnit",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5UTF16O8CodeUnita",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -109255,22 +121192,20 @@
                   "printedName": "UInt16",
                   "usr": "s:s6UInt16V"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s7UnicodeO5UTF16O8CodeUnita",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "EncodedScalar",
               "printedName": "EncodedScalar",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5UTF16O13EncodedScalara",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "_UIntBuffer",
                   "printedName": "_UIntBuffer<UInt32, UInt16>",
-                  "usr": "s:s11_UIntBufferV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -109284,22 +121219,18 @@
                       "printedName": "UInt16",
                       "usr": "s:s6UInt16V"
                     }
-                  ]
+                  ],
+                  "usr": "s:s11_UIntBufferV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s7UnicodeO5UTF16O13EncodedScalara",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "encodedReplacementCharacter",
               "printedName": "encodedReplacementCharacter",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO5UTF16O27encodedReplacementCharacters11_UIntBufferVys6UInt32Vs6UInt16VGvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -109310,7 +121241,6 @@
                       "kind": "TypeNominal",
                       "name": "_UIntBuffer",
                       "printedName": "_UIntBuffer<UInt32, UInt16>",
-                      "usr": "s:s11_UIntBufferV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -109324,7 +121254,8 @@
                           "printedName": "UInt16",
                           "usr": "s:s6UInt16V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s11_UIntBufferV"
                     }
                   ]
                 },
@@ -109332,11 +121263,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO5UTF16O27encodedReplacementCharacters11_UIntBufferVys6UInt32Vs6UInt16VGvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -109347,7 +121273,6 @@
                           "kind": "TypeNominal",
                           "name": "_UIntBuffer",
                           "printedName": "_UIntBuffer<UInt32, UInt16>",
-                          "usr": "s:s11_UIntBufferV",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -109361,26 +121286,30 @@
                               "printedName": "UInt16",
                               "usr": "s:s6UInt16V"
                             }
-                          ]
+                          ],
+                          "usr": "s:s11_UIntBufferV"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO5UTF16O27encodedReplacementCharacters11_UIntBufferVys6UInt32Vs6UInt16VGvgZ",
+                  "moduleName": "Swift",
+                  "static": true
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO5UTF16O27encodedReplacementCharacters11_UIntBufferVys6UInt32Vs6UInt16VGvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "decode",
               "printedName": "decode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O6decodeyAB6ScalarVs11_UIntBufferVys6UInt32Vs6UInt16VGFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -109397,7 +121326,6 @@
                       "kind": "TypeNominal",
                       "name": "_UIntBuffer",
                       "printedName": "_UIntBuffer<UInt32, UInt16>",
-                      "usr": "s:s11_UIntBufferV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -109411,30 +121339,29 @@
                           "printedName": "UInt16",
                           "usr": "s:s6UInt16V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s11_UIntBufferV"
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O6decodeyAB6ScalarVs11_UIntBufferVys6UInt32Vs6UInt16VGFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "encode",
               "printedName": "encode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O6encodeys11_UIntBufferVys6UInt32Vs6UInt16VGSgAB6ScalarVFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Unicode.UTF16.EncodedScalar?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -109445,7 +121372,6 @@
                           "kind": "TypeNominal",
                           "name": "_UIntBuffer",
                           "printedName": "_UIntBuffer<UInt32, UInt16>",
-                          "usr": "s:s11_UIntBufferV",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -109459,11 +121385,13 @@
                               "printedName": "UInt16",
                               "usr": "s:s6UInt16V"
                             }
-                          ]
+                          ],
+                          "usr": "s:s11_UIntBufferV"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -109471,28 +121399,24 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O6encodeys11_UIntBufferVys6UInt32Vs6UInt16VGSgAB6ScalarVFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "transcode",
               "printedName": "transcode(_:from:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O9transcode_4froms11_UIntBufferVys6UInt32Vs6UInt16VGSg13EncodedScalarQz_xmts01_A8EncodingRzlFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<FromEncoding where FromEncoding : _UnicodeEncoding>",
-              "static": true,
-              "declAttributes": [
-                "Inline",
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Unicode.UTF16.EncodedScalar?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -109503,7 +121427,6 @@
                           "kind": "TypeNominal",
                           "name": "_UIntBuffer",
                           "printedName": "_UIntBuffer<UInt32, UInt16>",
-                          "usr": "s:s11_UIntBufferV",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -109517,11 +121440,13 @@
                               "printedName": "UInt16",
                               "usr": "s:s6UInt16V"
                             }
-                          ]
+                          ],
+                          "usr": "s:s11_UIntBufferV"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -109540,35 +121465,26 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O9transcode_4froms11_UIntBufferVys6UInt32Vs6UInt16VGSg13EncodedScalarQz_xmts01_A8EncodingRzlFZ",
+              "moduleName": "Swift",
+              "genericSig": "<FromEncoding where FromEncoding : _UnicodeEncoding>",
+              "static": true,
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "ForwardParser",
               "printedName": "ForwardParser",
-              "declKind": "Struct",
-              "usr": "s:s7UnicodeO5UTF16O13ForwardParserV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "_UnicodeParser",
-                "_UTFParser"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
               "children": [
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init()",
-                  "declKind": "Constructor",
-                  "usr": "s:s7UnicodeO5UTF16O13ForwardParserVAFycfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -109576,16 +121492,18 @@
                       "printedName": "Unicode.UTF16.ForwardParser",
                       "usr": "s:s7UnicodeO5UTF16O13ForwardParserV"
                     }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:s7UnicodeO5UTF16O13ForwardParserVAFycfc",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
                   "kind": "TypeAlias",
                   "name": "Encoding",
                   "printedName": "Encoding",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO5UTF16O13ForwardParserV8Encodinga",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -109593,37 +121511,32 @@
                       "printedName": "Unicode.UTF16",
                       "usr": "s:s7UnicodeO5UTF16O"
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:s7UnicodeO5UTF16O13ForwardParserV8Encodinga",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Struct",
+              "usr": "s:s7UnicodeO5UTF16O13ForwardParserV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "_UnicodeParser",
+                "_UTFParser"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "ReverseParser",
               "printedName": "ReverseParser",
-              "declKind": "Struct",
-              "usr": "s:s7UnicodeO5UTF16O13ReverseParserV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "_UnicodeParser",
-                "_UTFParser"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
               "children": [
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init()",
-                  "declKind": "Constructor",
-                  "usr": "s:s7UnicodeO5UTF16O13ReverseParserVAFycfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -109631,16 +121544,18 @@
                       "printedName": "Unicode.UTF16.ReverseParser",
                       "usr": "s:s7UnicodeO5UTF16O13ReverseParserV"
                     }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:s7UnicodeO5UTF16O13ReverseParserVAFycfc",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
                   "kind": "TypeAlias",
                   "name": "Encoding",
                   "printedName": "Encoding",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO5UTF16O13ReverseParserV8Encodinga",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -109648,21 +121563,27 @@
                       "printedName": "Unicode.UTF16",
                       "usr": "s:s7UnicodeO5UTF16O"
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:s7UnicodeO5UTF16O13ReverseParserV8Encodinga",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Struct",
+              "usr": "s:s7UnicodeO5UTF16O13ReverseParserV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "_UnicodeParser",
+                "_UTFParser"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init()",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO5UTF16OADycfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -109670,21 +121591,18 @@
                   "printedName": "Unicode.UTF16",
                   "usr": "s:s7UnicodeO5UTF16O"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO5UTF16OADycfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "decode",
               "printedName": "decode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O6decodeys0A14DecodingResultOxzStRzs6UInt16V7ElementRtzlF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<I where I : IteratorProtocol, I.Element == Unicode.UTF16.CodeUnit>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -109697,20 +121615,20 @@
                   "name": "GenericTypeParam",
                   "printedName": "I"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O6decodeys0A14DecodingResultOxzStRzs6UInt16V7ElementRtzlF",
+              "moduleName": "Swift",
+              "genericSig": "<I where I : IteratorProtocol, I.Element == Unicode.UTF16.CodeUnit>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
               "kind": "Function",
               "name": "encode",
               "printedName": "encode(_:into:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O6encode_4intoyAB6ScalarV_ys6UInt16VXEtFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -109727,9 +121645,6 @@
                   "kind": "TypeFunc",
                   "name": "Function",
                   "printedName": "(Unicode.UTF16.CodeUnit) -> Void",
-                  "typeAttributes": [
-                    "noescape"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -109747,7 +121662,6 @@
                       "kind": "TypeNominal",
                       "name": "Paren",
                       "printedName": "(Unicode.UTF16.CodeUnit)",
-                      "usr": "s:s6UInt16V",
                       "children": [
                         {
                           "kind": "TypeNameAlias",
@@ -109762,24 +121676,27 @@
                             }
                           ]
                         }
-                      ]
+                      ],
+                      "usr": "s:s6UInt16V"
                     }
+                  ],
+                  "typeAttributes": [
+                    "noescape"
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O6encode_4intoyAB6ScalarV_ys6UInt16VXEtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "width",
               "printedName": "width(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O5widthySiAB6ScalarVFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -109793,20 +121710,19 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O5widthySiAB6ScalarVFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "leadSurrogate",
               "printedName": "leadSurrogate(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O13leadSurrogateys6UInt16VAB6ScalarVFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -109827,20 +121743,19 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O13leadSurrogateys6UInt16VAB6ScalarVFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "trailSurrogate",
               "printedName": "trailSurrogate(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O14trailSurrogateys6UInt16VAB6ScalarVFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -109861,20 +121776,19 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O14trailSurrogateys6UInt16VAB6ScalarVFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "isLeadSurrogate",
               "printedName": "isLeadSurrogate(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O15isLeadSurrogateySbs6UInt16VFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -109895,20 +121809,19 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O15isLeadSurrogateySbs6UInt16VFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "isTrailSurrogate",
               "printedName": "isTrailSurrogate(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O16isTrailSurrogateySbs6UInt16VFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -109929,27 +121842,24 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O16isTrailSurrogateySbs6UInt16VFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "transcodedLength",
               "printedName": "transcodedLength(of:decodedAs:repairingIllFormedSequences:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF16O16transcodedLength2of9decodedAs27repairingIllFormedSequencesSi5count_Sb7isASCIItSgx_q_mSbtStRzs01_A8EncodingR_8CodeUnitQy_7ElementRtzr0_lFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Input, Encoding where Input : IteratorProtocol, Encoding : _UnicodeEncoding, Input.Element == Encoding.CodeUnit>",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "(count: Int, isASCII: Bool)?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -109970,7 +121880,8 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -109995,34 +121906,37 @@
                   "printedName": "Bool",
                   "usr": "s:Sb"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF16O16transcodedLength2of9decodedAs27repairingIllFormedSequencesSi5count_Sb7isASCIItSgx_q_mSbtStRzs01_A8EncodingR_8CodeUnitQy_7ElementRtzr0_lFZ",
+              "moduleName": "Swift",
+              "genericSig": "<Input, Encoding where Input : IteratorProtocol, Encoding : _UnicodeEncoding, Input.Element == Encoding.CodeUnit>",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Enum",
+          "usr": "s:s7UnicodeO5UTF16O",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Frozen"
+          ],
+          "conformingProtocols": [
+            "_UnicodeEncoding",
+            "UnicodeCodec"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "UTF8",
           "printedName": "UTF8",
-          "declKind": "Enum",
-          "usr": "s:s7UnicodeO4UTF8O",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "_UnicodeEncoding",
-            "UnicodeCodec"
-          ],
-          "declAttributes": [
-            "Frozen"
-          ],
           "children": [
             {
               "kind": "TypeAlias",
               "name": "CodeUnit",
               "printedName": "CodeUnit",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO4UTF8O8CodeUnita",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -110030,22 +121944,20 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s7UnicodeO4UTF8O8CodeUnita",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "EncodedScalar",
               "printedName": "EncodedScalar",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO4UTF8O13EncodedScalara",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "_ValidUTF8Buffer",
                   "printedName": "_ValidUTF8Buffer<UInt32>",
-                  "usr": "s:s16_ValidUTF8BufferV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -110053,22 +121965,18 @@
                       "printedName": "UInt32",
                       "usr": "s:s6UInt32V"
                     }
-                  ]
+                  ],
+                  "usr": "s:s16_ValidUTF8BufferV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s7UnicodeO4UTF8O13EncodedScalara",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "encodedReplacementCharacter",
               "printedName": "encodedReplacementCharacter",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO4UTF8O27encodedReplacementCharacters06_ValidB6BufferVys6UInt32VGvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -110079,7 +121987,6 @@
                       "kind": "TypeNominal",
                       "name": "_ValidUTF8Buffer",
                       "printedName": "_ValidUTF8Buffer<UInt32>",
-                      "usr": "s:s16_ValidUTF8BufferV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -110087,7 +121994,8 @@
                           "printedName": "UInt32",
                           "usr": "s:s6UInt32V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s16_ValidUTF8BufferV"
                     }
                   ]
                 },
@@ -110095,11 +122003,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO4UTF8O27encodedReplacementCharacters06_ValidB6BufferVys6UInt32VGvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -110110,7 +122013,6 @@
                           "kind": "TypeNominal",
                           "name": "_ValidUTF8Buffer",
                           "printedName": "_ValidUTF8Buffer<UInt32>",
-                          "usr": "s:s16_ValidUTF8BufferV",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -110118,27 +122020,30 @@
                               "printedName": "UInt32",
                               "usr": "s:s6UInt32V"
                             }
-                          ]
+                          ],
+                          "usr": "s:s16_ValidUTF8BufferV"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO4UTF8O27encodedReplacementCharacters06_ValidB6BufferVys6UInt32VGvgZ",
+                  "moduleName": "Swift",
+                  "static": true
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO4UTF8O27encodedReplacementCharacters06_ValidB6BufferVys6UInt32VGvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "decode",
               "printedName": "decode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO4UTF8O6decodeyAB6ScalarVs06_ValidB6BufferVys6UInt32VGFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable",
-                "Inline"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -110155,7 +122060,6 @@
                       "kind": "TypeNominal",
                       "name": "_ValidUTF8Buffer",
                       "printedName": "_ValidUTF8Buffer<UInt32>",
-                      "usr": "s:s16_ValidUTF8BufferV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -110163,31 +122067,30 @@
                           "printedName": "UInt32",
                           "usr": "s:s6UInt32V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s16_ValidUTF8BufferV"
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO4UTF8O6decodeyAB6ScalarVs06_ValidB6BufferVys6UInt32VGFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable",
+                "Inline"
               ]
             },
             {
               "kind": "Function",
               "name": "encode",
               "printedName": "encode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO4UTF8O6encodeys06_ValidB6BufferVys6UInt32VGSgAB6ScalarVFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable",
-                "Inline"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Unicode.UTF8.EncodedScalar?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -110198,7 +122101,6 @@
                           "kind": "TypeNominal",
                           "name": "_ValidUTF8Buffer",
                           "printedName": "_ValidUTF8Buffer<UInt32>",
-                          "usr": "s:s16_ValidUTF8BufferV",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -110206,11 +122108,13 @@
                               "printedName": "UInt32",
                               "usr": "s:s6UInt32V"
                             }
-                          ]
+                          ],
+                          "usr": "s:s16_ValidUTF8BufferV"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -110218,28 +122122,25 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO4UTF8O6encodeys06_ValidB6BufferVys6UInt32VGSgAB6ScalarVFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable",
+                "Inline"
               ]
             },
             {
               "kind": "Function",
               "name": "transcode",
               "printedName": "transcode(_:from:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO4UTF8O9transcode_4froms06_ValidB6BufferVys6UInt32VGSg13EncodedScalarQz_xmts01_A8EncodingRzlFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<FromEncoding where FromEncoding : _UnicodeEncoding>",
-              "static": true,
-              "declAttributes": [
-                "Inline",
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Unicode.UTF8.EncodedScalar?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -110250,7 +122151,6 @@
                           "kind": "TypeNominal",
                           "name": "_ValidUTF8Buffer",
                           "printedName": "_ValidUTF8Buffer<UInt32>",
-                          "usr": "s:s16_ValidUTF8BufferV",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -110258,11 +122158,13 @@
                               "printedName": "UInt32",
                               "usr": "s:s6UInt32V"
                             }
-                          ]
+                          ],
+                          "usr": "s:s16_ValidUTF8BufferV"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -110281,36 +122183,26 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO4UTF8O9transcode_4froms06_ValidB6BufferVys6UInt32VGSg13EncodedScalarQz_xmts01_A8EncodingRzlFZ",
+              "moduleName": "Swift",
+              "genericSig": "<FromEncoding where FromEncoding : _UnicodeEncoding>",
+              "static": true,
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "ForwardParser",
               "printedName": "ForwardParser",
-              "declKind": "Struct",
-              "usr": "s:s7UnicodeO4UTF8O13ForwardParserV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "_UnicodeParser",
-                "_UTFParser"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
               "children": [
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init()",
-                  "declKind": "Constructor",
-                  "usr": "s:s7UnicodeO4UTF8O13ForwardParserVAFycfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable",
-                    "Inline"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -110318,16 +122210,19 @@
                       "printedName": "Unicode.UTF8.ForwardParser",
                       "usr": "s:s7UnicodeO4UTF8O13ForwardParserV"
                     }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:s7UnicodeO4UTF8O13ForwardParserVAFycfc",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable",
+                    "Inline"
                   ]
                 },
                 {
                   "kind": "TypeAlias",
                   "name": "Encoding",
                   "printedName": "Encoding",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO4UTF8O13ForwardParserV8Encodinga",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -110335,38 +122230,32 @@
                       "printedName": "Unicode.UTF8",
                       "usr": "s:s7UnicodeO4UTF8O"
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:s7UnicodeO4UTF8O13ForwardParserV8Encodinga",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Struct",
+              "usr": "s:s7UnicodeO4UTF8O13ForwardParserV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "_UnicodeParser",
+                "_UTFParser"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "ReverseParser",
               "printedName": "ReverseParser",
-              "declKind": "Struct",
-              "usr": "s:s7UnicodeO4UTF8O13ReverseParserV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "_UnicodeParser",
-                "_UTFParser"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
               "children": [
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init()",
-                  "declKind": "Constructor",
-                  "usr": "s:s7UnicodeO4UTF8O13ReverseParserVAFycfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable",
-                    "Inline"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -110374,16 +122263,19 @@
                       "printedName": "Unicode.UTF8.ReverseParser",
                       "usr": "s:s7UnicodeO4UTF8O13ReverseParserV"
                     }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:s7UnicodeO4UTF8O13ReverseParserVAFycfc",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable",
+                    "Inline"
                   ]
                 },
                 {
                   "kind": "TypeAlias",
                   "name": "Encoding",
                   "printedName": "Encoding",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO4UTF8O13ReverseParserV8Encodinga",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -110391,21 +122283,27 @@
                       "printedName": "Unicode.UTF8",
                       "usr": "s:s7UnicodeO4UTF8O"
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:s7UnicodeO4UTF8O13ReverseParserV8Encodinga",
+                  "moduleName": "Swift"
                 }
+              ],
+              "declKind": "Struct",
+              "usr": "s:s7UnicodeO4UTF8O13ReverseParserV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "_UnicodeParser",
+                "_UTFParser"
               ]
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init()",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO4UTF8OADycfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -110413,22 +122311,18 @@
                   "printedName": "Unicode.UTF8",
                   "usr": "s:s7UnicodeO4UTF8O"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO4UTF8OADycfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "decode",
               "printedName": "decode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO4UTF8O6decodeys0A14DecodingResultOxzStRzs5UInt8V7ElementRtzlF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<I where I : IteratorProtocol, I.Element == Unicode.UTF8.CodeUnit>",
-              "mutating": true,
-              "declAttributes": [
-                "Inline",
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -110441,21 +122335,21 @@
                   "name": "GenericTypeParam",
                   "printedName": "I"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO4UTF8O6decodeys0A14DecodingResultOxzStRzs5UInt8V7ElementRtzlF",
+              "moduleName": "Swift",
+              "genericSig": "<I where I : IteratorProtocol, I.Element == Unicode.UTF8.CodeUnit>",
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
               "kind": "Function",
               "name": "encode",
               "printedName": "encode(_:into:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO4UTF8O6encode_4intoyAB6ScalarV_ys5UInt8VXEtFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inline",
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -110472,9 +122366,6 @@
                   "kind": "TypeFunc",
                   "name": "Function",
                   "printedName": "(Unicode.UTF8.CodeUnit) -> Void",
-                  "typeAttributes": [
-                    "noescape"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -110492,7 +122383,6 @@
                       "kind": "TypeNominal",
                       "name": "Paren",
                       "printedName": "(Unicode.UTF8.CodeUnit)",
-                      "usr": "s:s5UInt8V",
                       "children": [
                         {
                           "kind": "TypeNameAlias",
@@ -110507,24 +122397,28 @@
                             }
                           ]
                         }
-                      ]
+                      ],
+                      "usr": "s:s5UInt8V"
                     }
+                  ],
+                  "typeAttributes": [
+                    "noescape"
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO4UTF8O6encode_4intoyAB6ScalarV_ys5UInt8VXEtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "isContinuation",
               "printedName": "isContinuation(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO4UTF8O14isContinuationySbs5UInt8VFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -110545,31 +122439,36 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO4UTF8O14isContinuationySbs5UInt8VFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Enum",
+          "usr": "s:s7UnicodeO4UTF8O",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Frozen"
+          ],
+          "conformingProtocols": [
+            "_UnicodeEncoding",
+            "UnicodeCodec"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "ParseResult",
           "printedName": "ParseResult",
-          "declKind": "Enum",
-          "usr": "s:s7UnicodeO11ParseResultO",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<T>",
-          "declAttributes": [
-            "Frozen"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "valid",
               "printedName": "valid",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO11ParseResultO5validyADy_xGxcAFmlF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -110585,14 +122484,14 @@
                           "kind": "TypeNominal",
                           "name": "ParseResult",
                           "printedName": "Unicode.ParseResult<T>",
-                          "usr": "s:s7UnicodeO11ParseResultO",
                           "children": [
                             {
                               "kind": "TypeNominal",
                               "name": "GenericTypeParam",
                               "printedName": "T"
                             }
-                          ]
+                          ],
+                          "usr": "s:s7UnicodeO11ParseResultO"
                         },
                         {
                           "kind": "TypeNominal",
@@ -110622,14 +122521,14 @@
                               "kind": "TypeNominal",
                               "name": "ParseResult",
                               "printedName": "Unicode.ParseResult<T>",
-                              "usr": "s:s7UnicodeO11ParseResultO",
                               "children": [
                                 {
                                   "kind": "TypeNominal",
                                   "name": "GenericTypeParam",
                                   "printedName": "T"
                                 }
-                              ]
+                              ],
+                              "usr": "s:s7UnicodeO11ParseResultO"
                             }
                           ]
                         }
@@ -110637,16 +122536,16 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO11ParseResultO5validyADy_xGxcAFmlF",
+              "moduleName": "Swift",
+              "fixedbinaryorder": 0
             },
             {
               "kind": "Var",
               "name": "emptyInput",
               "printedName": "emptyInput",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO11ParseResultO10emptyInputyADy_xGAFmlF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -110657,14 +122556,14 @@
                       "kind": "TypeNominal",
                       "name": "ParseResult",
                       "printedName": "Unicode.ParseResult<T>",
-                      "usr": "s:s7UnicodeO11ParseResultO",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
                           "printedName": "T"
                         }
-                      ]
+                      ],
+                      "usr": "s:s7UnicodeO11ParseResultO"
                     },
                     {
                       "kind": "TypeNominal",
@@ -110680,14 +122579,14 @@
                               "kind": "TypeNominal",
                               "name": "ParseResult",
                               "printedName": "Unicode.ParseResult<T>",
-                              "usr": "s:s7UnicodeO11ParseResultO",
                               "children": [
                                 {
                                   "kind": "TypeNominal",
                                   "name": "GenericTypeParam",
                                   "printedName": "T"
                                 }
-                              ]
+                              ],
+                              "usr": "s:s7UnicodeO11ParseResultO"
                             }
                           ]
                         }
@@ -110695,16 +122594,16 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO11ParseResultO10emptyInputyADy_xGAFmlF",
+              "moduleName": "Swift",
+              "fixedbinaryorder": 1
             },
             {
               "kind": "Var",
               "name": "error",
               "printedName": "error",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO11ParseResultO5erroryADy_xGSi_tcAFmlF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -110720,14 +122619,14 @@
                           "kind": "TypeNominal",
                           "name": "ParseResult",
                           "printedName": "Unicode.ParseResult<T>",
-                          "usr": "s:s7UnicodeO11ParseResultO",
                           "children": [
                             {
                               "kind": "TypeNominal",
                               "name": "GenericTypeParam",
                               "printedName": "T"
                             }
-                          ]
+                          ],
+                          "usr": "s:s7UnicodeO11ParseResultO"
                         },
                         {
                           "kind": "TypeNominal",
@@ -110758,14 +122657,14 @@
                               "kind": "TypeNominal",
                               "name": "ParseResult",
                               "printedName": "Unicode.ParseResult<T>",
-                              "usr": "s:s7UnicodeO11ParseResultO",
                               "children": [
                                 {
                                   "kind": "TypeNominal",
                                   "name": "GenericTypeParam",
                                   "printedName": "T"
                                 }
-                              ]
+                              ],
+                              "usr": "s:s7UnicodeO11ParseResultO"
                             }
                           ]
                         }
@@ -110773,18 +122672,25 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO11ParseResultO5erroryADy_xGSi_tcAFmlF",
+              "moduleName": "Swift",
+              "fixedbinaryorder": 2
             }
+          ],
+          "declKind": "Enum",
+          "usr": "s:s7UnicodeO11ParseResultO",
+          "moduleName": "Swift",
+          "genericSig": "<T>",
+          "declAttributes": [
+            "Frozen"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Version",
           "printedName": "Version",
-          "declKind": "TypeAlias",
-          "usr": "s:s7UnicodeO7Versiona",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -110805,29 +122711,20 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s7UnicodeO7Versiona",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeDecl",
           "name": "GeneralCategory",
           "printedName": "GeneralCategory",
-          "declKind": "Enum",
-          "usr": "s:s7UnicodeO15GeneralCategoryO",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "Equatable",
-            "Hashable"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "uppercaseLetter",
               "printedName": "uppercaseLetter",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO15uppercaseLetteryA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -110862,16 +122759,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO15uppercaseLetteryA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "lowercaseLetter",
               "printedName": "lowercaseLetter",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO15lowercaseLetteryA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -110906,16 +122802,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO15lowercaseLetteryA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "titlecaseLetter",
               "printedName": "titlecaseLetter",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO15titlecaseLetteryA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -110950,16 +122845,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO15titlecaseLetteryA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "modifierLetter",
               "printedName": "modifierLetter",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO14modifierLetteryA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -110994,16 +122888,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO14modifierLetteryA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "otherLetter",
               "printedName": "otherLetter",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO11otherLetteryA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111038,16 +122931,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO11otherLetteryA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "nonspacingMark",
               "printedName": "nonspacingMark",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO14nonspacingMarkyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111082,16 +122974,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO14nonspacingMarkyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "spacingMark",
               "printedName": "spacingMark",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO11spacingMarkyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111126,16 +123017,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO11spacingMarkyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "enclosingMark",
               "printedName": "enclosingMark",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO13enclosingMarkyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111170,16 +123060,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO13enclosingMarkyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "decimalNumber",
               "printedName": "decimalNumber",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO13decimalNumberyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111214,16 +123103,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO13decimalNumberyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "letterNumber",
               "printedName": "letterNumber",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO12letterNumberyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111258,16 +123146,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO12letterNumberyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "otherNumber",
               "printedName": "otherNumber",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO11otherNumberyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111302,16 +123189,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO11otherNumberyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "connectorPunctuation",
               "printedName": "connectorPunctuation",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO20connectorPunctuationyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111346,16 +123232,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO20connectorPunctuationyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "dashPunctuation",
               "printedName": "dashPunctuation",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO15dashPunctuationyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111390,16 +123275,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO15dashPunctuationyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "openPunctuation",
               "printedName": "openPunctuation",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO15openPunctuationyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111434,16 +123318,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO15openPunctuationyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "closePunctuation",
               "printedName": "closePunctuation",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO16closePunctuationyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111478,16 +123361,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO16closePunctuationyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "initialPunctuation",
               "printedName": "initialPunctuation",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO18initialPunctuationyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111522,16 +123404,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO18initialPunctuationyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "finalPunctuation",
               "printedName": "finalPunctuation",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO16finalPunctuationyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111566,16 +123447,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO16finalPunctuationyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "otherPunctuation",
               "printedName": "otherPunctuation",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO16otherPunctuationyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111610,16 +123490,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO16otherPunctuationyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "mathSymbol",
               "printedName": "mathSymbol",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO10mathSymbolyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111654,16 +123533,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO10mathSymbolyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "currencySymbol",
               "printedName": "currencySymbol",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO14currencySymbolyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111698,16 +123576,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO14currencySymbolyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "modifierSymbol",
               "printedName": "modifierSymbol",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO14modifierSymbolyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111742,16 +123619,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO14modifierSymbolyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "otherSymbol",
               "printedName": "otherSymbol",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO11otherSymbolyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111786,16 +123662,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO11otherSymbolyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "spaceSeparator",
               "printedName": "spaceSeparator",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO14spaceSeparatoryA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111830,16 +123705,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO14spaceSeparatoryA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "lineSeparator",
               "printedName": "lineSeparator",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO13lineSeparatoryA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111874,16 +123748,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO13lineSeparatoryA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "paragraphSeparator",
               "printedName": "paragraphSeparator",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO18paragraphSeparatoryA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111918,16 +123791,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO18paragraphSeparatoryA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "control",
               "printedName": "control",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO7controlyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -111962,16 +123834,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO7controlyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "format",
               "printedName": "format",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO6formatyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -112006,16 +123877,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO6formatyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "surrogate",
               "printedName": "surrogate",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO9surrogateyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -112050,16 +123920,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO9surrogateyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "privateUse",
               "printedName": "privateUse",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO10privateUseyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -112094,16 +123963,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO10privateUseyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "unassigned",
               "printedName": "unassigned",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO15GeneralCategoryO10unassignedyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -112138,16 +124006,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO15GeneralCategoryO10unassignedyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(rawValue:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO15GeneralCategoryO8rawValueADSo020__swift_stdlib_UCharC0V_tcfc",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112161,16 +124028,49 @@
                   "printedName": "__swift_stdlib_UCharCategory",
                   "usr": "c:@E@__swift_stdlib_UCharCategory"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO15GeneralCategoryO8rawValueADSo020__swift_stdlib_UCharC0V_tcfc",
+              "moduleName": "Swift",
+              "isInternal": true
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GeneralCategory",
+                  "printedName": "Unicode.GeneralCategory",
+                  "usr": "s:s7UnicodeO15GeneralCategoryO"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "GeneralCategory",
+                  "printedName": "Unicode.GeneralCategory",
+                  "usr": "s:s7UnicodeO15GeneralCategoryO"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO15GeneralCategoryO2eeoiySbAD_ADtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "implicit": true,
+              "declAttributes": [
+                "Infix"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO15GeneralCategoryO9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112182,10 +124082,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO15GeneralCategoryO9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112193,18 +124089,22 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO15GeneralCategoryO9hashValueSivg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO15GeneralCategoryO9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO15GeneralCategoryO4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112217,37 +124117,30 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO15GeneralCategoryO4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Enum",
+          "usr": "s:s7UnicodeO15GeneralCategoryO",
+          "moduleName": "Swift",
+          "conformingProtocols": [
+            "Equatable",
+            "Hashable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "CanonicalCombiningClass",
           "printedName": "CanonicalCombiningClass",
-          "declKind": "Struct",
-          "usr": "s:s7UnicodeO23CanonicalCombiningClassV",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "Comparable",
-            "Hashable",
-            "RawRepresentable",
-            "Equatable"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "notReordered",
               "printedName": "notReordered",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV12notReorderedADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112259,11 +124152,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV12notReorderedADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112271,22 +124159,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV12notReorderedADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV12notReorderedADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "overlay",
               "printedName": "overlay",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV7overlayADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112298,11 +124192,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV7overlayADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112310,22 +124199,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV7overlayADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV7overlayADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "nukta",
               "printedName": "nukta",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV5nuktaADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112337,11 +124232,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV5nuktaADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112349,22 +124239,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV5nuktaADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV5nuktaADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "kanaVoicing",
               "printedName": "kanaVoicing",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV11kanaVoicingADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112376,11 +124272,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV11kanaVoicingADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112388,22 +124279,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV11kanaVoicingADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV11kanaVoicingADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "virama",
               "printedName": "virama",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV6viramaADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112415,11 +124312,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV6viramaADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112427,22 +124319,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV6viramaADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV6viramaADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "attachedBelowLeft",
               "printedName": "attachedBelowLeft",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV17attachedBelowLeftADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112454,11 +124352,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV17attachedBelowLeftADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112466,22 +124359,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV17attachedBelowLeftADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV17attachedBelowLeftADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "attachedBelow",
               "printedName": "attachedBelow",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV13attachedBelowADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112493,11 +124392,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV13attachedBelowADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112505,22 +124399,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV13attachedBelowADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV13attachedBelowADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "attachedAbove",
               "printedName": "attachedAbove",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV13attachedAboveADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112532,11 +124432,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV13attachedAboveADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112544,22 +124439,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV13attachedAboveADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV13attachedAboveADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "attachedAboveRight",
               "printedName": "attachedAboveRight",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV18attachedAboveRightADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112571,11 +124472,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV18attachedAboveRightADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112583,22 +124479,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV18attachedAboveRightADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV18attachedAboveRightADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "belowLeft",
               "printedName": "belowLeft",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV9belowLeftADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112610,11 +124512,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV9belowLeftADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112622,22 +124519,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV9belowLeftADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV9belowLeftADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "below",
               "printedName": "below",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV5belowADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112649,11 +124552,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV5belowADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112661,22 +124559,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV5belowADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV5belowADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "belowRight",
               "printedName": "belowRight",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV10belowRightADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112688,11 +124592,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV10belowRightADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112700,22 +124599,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV10belowRightADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV10belowRightADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "left",
               "printedName": "left",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV4leftADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112727,11 +124632,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV4leftADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112739,22 +124639,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV4leftADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV4leftADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "right",
               "printedName": "right",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV5rightADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112766,11 +124672,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV5rightADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112778,22 +124679,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV5rightADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV5rightADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "aboveLeft",
               "printedName": "aboveLeft",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV9aboveLeftADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112805,11 +124712,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV9aboveLeftADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112817,22 +124719,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV9aboveLeftADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV9aboveLeftADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "above",
               "printedName": "above",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV5aboveADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112844,11 +124752,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV5aboveADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112856,22 +124759,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV5aboveADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV5aboveADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "aboveRight",
               "printedName": "aboveRight",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV10aboveRightADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112883,11 +124792,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV10aboveRightADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112895,22 +124799,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV10aboveRightADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV10aboveRightADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "doubleBelow",
               "printedName": "doubleBelow",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV11doubleBelowADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112922,11 +124832,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV11doubleBelowADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112934,22 +124839,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV11doubleBelowADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV11doubleBelowADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "doubleAbove",
               "printedName": "doubleAbove",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV11doubleAboveADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -112961,11 +124872,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV11doubleAboveADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -112973,22 +124879,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV11doubleAboveADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV11doubleAboveADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "iotaSubscript",
               "printedName": "iotaSubscript",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV13iotaSubscriptADvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "HasInitialValue"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113000,11 +124912,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV13iotaSubscriptADvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -113012,18 +124919,28 @@
                       "printedName": "Unicode.CanonicalCombiningClass",
                       "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV13iotaSubscriptADvgZ",
+                  "moduleName": "Swift",
+                  "static": true,
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV13iotaSubscriptADvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "HasInitialValue"
+              ],
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Var",
               "name": "rawValue",
               "printedName": "rawValue",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV8rawValues5UInt8Vvp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113035,10 +124952,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV8rawValues5UInt8Vvg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -113046,18 +124959,23 @@
                       "printedName": "UInt8",
                       "usr": "s:s5UInt8V"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV8rawValues5UInt8Vvg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV8rawValues5UInt8Vvp",
+              "moduleName": "Swift",
+              "isLet": true,
+              "hasStorage": true
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(rawValue:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV8rawValueADs5UInt8V_tcfc",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113071,16 +124989,44 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV8rawValueADs5UInt8V_tcfc",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Function",
+              "name": "<",
+              "printedName": "<(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "CanonicalCombiningClass",
+                  "printedName": "Unicode.CanonicalCombiningClass",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "CanonicalCombiningClass",
+                  "printedName": "Unicode.CanonicalCombiningClass",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV1loiySbAD_ADtFZ",
+              "moduleName": "Swift",
+              "static": true
             },
             {
               "kind": "TypeAlias",
               "name": "RawValue",
               "printedName": "RawValue",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV8RawValuea",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113088,16 +125034,16 @@
                   "printedName": "UInt8",
                   "usr": "s:s5UInt8V"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV8RawValuea",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113109,10 +125055,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -113120,18 +125062,22 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO23CanonicalCombiningClassV9hashValueSivg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO23CanonicalCombiningClassV4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113144,31 +125090,32 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO23CanonicalCombiningClassV4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s7UnicodeO23CanonicalCombiningClassV",
+          "moduleName": "Swift",
+          "conformingProtocols": [
+            "Comparable",
+            "Hashable",
+            "RawRepresentable",
+            "Equatable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "NumericType",
           "printedName": "NumericType",
-          "declKind": "Enum",
-          "usr": "s:s7UnicodeO11NumericTypeO",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "Equatable",
-            "Hashable"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "decimal",
               "printedName": "decimal",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO11NumericTypeO7decimalyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -113203,16 +125150,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO11NumericTypeO7decimalyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "digit",
               "printedName": "digit",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO11NumericTypeO5digityA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -113247,16 +125193,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO11NumericTypeO5digityA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "numeric",
               "printedName": "numeric",
-              "declKind": "EnumElement",
-              "usr": "s:s7UnicodeO11NumericTypeO7numericyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -113291,22 +125236,20 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s7UnicodeO11NumericTypeO7numericyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(rawValue:)",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO11NumericTypeO8rawValueADSgSo023__swift_stdlib_UNumericC0V_tcfc",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Unicode.NumericType?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -113314,7 +125257,8 @@
                       "printedName": "Unicode.NumericType",
                       "usr": "s:s7UnicodeO11NumericTypeO"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -113322,16 +125266,49 @@
                   "printedName": "__swift_stdlib_UNumericType",
                   "usr": "c:@E@__swift_stdlib_UNumericType"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO11NumericTypeO8rawValueADSgSo023__swift_stdlib_UNumericC0V_tcfc",
+              "moduleName": "Swift",
+              "isInternal": true
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "NumericType",
+                  "printedName": "Unicode.NumericType",
+                  "usr": "s:s7UnicodeO11NumericTypeO"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "NumericType",
+                  "printedName": "Unicode.NumericType",
+                  "usr": "s:s7UnicodeO11NumericTypeO"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO11NumericTypeO2eeoiySbAD_ADtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "implicit": true,
+              "declAttributes": [
+                "Infix"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO11NumericTypeO9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113343,10 +125320,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO11NumericTypeO9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -113354,18 +125327,22 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO11NumericTypeO9hashValueSivg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO11NumericTypeO9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO11NumericTypeO4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113378,36 +125355,63 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO11NumericTypeO4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Enum",
+          "usr": "s:s7UnicodeO11NumericTypeO",
+          "moduleName": "Swift",
+          "conformingProtocols": [
+            "Equatable",
+            "Hashable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "UTF32",
           "printedName": "UTF32",
-          "declKind": "Enum",
-          "usr": "s:s7UnicodeO5UTF32O",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "Equatable",
-            "Hashable",
-            "_UnicodeEncoding",
-            "UnicodeCodec"
-          ],
-          "declAttributes": [
-            "Frozen"
-          ],
           "children": [
             {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF32",
+                  "printedName": "Unicode.UTF32",
+                  "usr": "s:s7UnicodeO5UTF32O"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "UTF32",
+                  "printedName": "Unicode.UTF32",
+                  "usr": "s:s7UnicodeO5UTF32O"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF32O2eeoiySbAD_ADtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "implicit": true,
+              "declAttributes": [
+                "Infix"
+              ]
+            },
+            {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO5UTF32O9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113419,10 +125423,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO5UTF32O9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -113430,18 +125430,22 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO5UTF32O9hashValueSivg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO5UTF32O9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF32O4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113454,16 +125458,16 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF32O4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "TypeAlias",
               "name": "CodeUnit",
               "printedName": "CodeUnit",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5UTF32O8CodeUnita",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113471,22 +125475,20 @@
                   "printedName": "UInt32",
                   "usr": "s:s6UInt32V"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s7UnicodeO5UTF32O8CodeUnita",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "EncodedScalar",
               "printedName": "EncodedScalar",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5UTF32O13EncodedScalara",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "CollectionOfOne",
                   "printedName": "CollectionOfOne<UInt32>",
-                  "usr": "s:s15CollectionOfOneV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -113494,22 +125496,18 @@
                       "printedName": "UInt32",
                       "usr": "s:s6UInt32V"
                     }
-                  ]
+                  ],
+                  "usr": "s:s15CollectionOfOneV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s7UnicodeO5UTF32O13EncodedScalara",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "encodedReplacementCharacter",
               "printedName": "encodedReplacementCharacter",
-              "declKind": "Var",
-              "usr": "s:s7UnicodeO5UTF32O27encodedReplacementCharacters15CollectionOfOneVys6UInt32VGvpZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -113520,7 +125518,6 @@
                       "kind": "TypeNominal",
                       "name": "CollectionOfOne",
                       "printedName": "CollectionOfOne<UInt32>",
-                      "usr": "s:s15CollectionOfOneV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -113528,7 +125525,8 @@
                           "printedName": "UInt32",
                           "usr": "s:s6UInt32V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s15CollectionOfOneV"
                     }
                   ]
                 },
@@ -113536,11 +125534,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s7UnicodeO5UTF32O27encodedReplacementCharacters15CollectionOfOneVys6UInt32VGvgZ",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "static": true,
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -113551,7 +125544,6 @@
                           "kind": "TypeNominal",
                           "name": "CollectionOfOne",
                           "printedName": "CollectionOfOne<UInt32>",
-                          "usr": "s:s15CollectionOfOneV",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -113559,27 +125551,30 @@
                               "printedName": "UInt32",
                               "usr": "s:s6UInt32V"
                             }
-                          ]
+                          ],
+                          "usr": "s:s15CollectionOfOneV"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s7UnicodeO5UTF32O27encodedReplacementCharacters15CollectionOfOneVys6UInt32VGvgZ",
+                  "moduleName": "Swift",
+                  "static": true
                 }
+              ],
+              "declKind": "Var",
+              "usr": "s:s7UnicodeO5UTF32O27encodedReplacementCharacters15CollectionOfOneVys6UInt32VGvpZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "decode",
               "printedName": "decode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF32O6decodeyAB6ScalarVs15CollectionOfOneVys6UInt32VGFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inline",
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113596,7 +125591,6 @@
                       "kind": "TypeNominal",
                       "name": "CollectionOfOne",
                       "printedName": "CollectionOfOne<UInt32>",
-                      "usr": "s:s15CollectionOfOneV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -113604,31 +125598,30 @@
                           "printedName": "UInt32",
                           "usr": "s:s6UInt32V"
                         }
-                      ]
+                      ],
+                      "usr": "s:s15CollectionOfOneV"
                     }
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF32O6decodeyAB6ScalarVs15CollectionOfOneVys6UInt32VGFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "encode",
               "printedName": "encode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF32O6encodeys15CollectionOfOneVys6UInt32VGSgAB6ScalarVFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inline",
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Unicode.UTF32.EncodedScalar?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -113639,7 +125632,6 @@
                           "kind": "TypeNominal",
                           "name": "CollectionOfOne",
                           "printedName": "CollectionOfOne<UInt32>",
-                          "usr": "s:s15CollectionOfOneV",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -113647,11 +125639,13 @@
                               "printedName": "UInt32",
                               "usr": "s:s6UInt32V"
                             }
-                          ]
+                          ],
+                          "usr": "s:s15CollectionOfOneV"
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -113659,34 +125653,25 @@
                   "printedName": "Unicode.Scalar",
                   "usr": "s:s7UnicodeO6ScalarV"
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF32O6encodeys15CollectionOfOneVys6UInt32VGSgAB6ScalarVFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inline",
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeDecl",
               "name": "Parser",
               "printedName": "Parser",
-              "declKind": "Struct",
-              "usr": "s:s7UnicodeO5UTF32O6ParserV",
-              "location": "",
-              "moduleName": "Swift",
-              "conformingProtocols": [
-                "_UnicodeParser"
-              ],
-              "declAttributes": [
-                "FixedLayout"
-              ],
               "children": [
                 {
                   "kind": "Constructor",
                   "name": "init",
                   "printedName": "init()",
-                  "declKind": "Constructor",
-                  "usr": "s:s7UnicodeO5UTF32O6ParserVAFycfc",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -113694,16 +125679,18 @@
                       "printedName": "Unicode.UTF32.Parser",
                       "usr": "s:s7UnicodeO5UTF32O6ParserV"
                     }
+                  ],
+                  "declKind": "Constructor",
+                  "usr": "s:s7UnicodeO5UTF32O6ParserVAFycfc",
+                  "moduleName": "Swift",
+                  "declAttributes": [
+                    "Inlinable"
                   ]
                 },
                 {
                   "kind": "TypeAlias",
                   "name": "Encoding",
                   "printedName": "Encoding",
-                  "declKind": "TypeAlias",
-                  "usr": "s:s7UnicodeO5UTF32O6ParserV8Encodinga",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -113711,27 +125698,20 @@
                       "printedName": "Unicode.UTF32",
                       "usr": "s:s7UnicodeO5UTF32O"
                     }
-                  ]
+                  ],
+                  "declKind": "TypeAlias",
+                  "usr": "s:s7UnicodeO5UTF32O6ParserV8Encodinga",
+                  "moduleName": "Swift"
                 },
                 {
                   "kind": "Function",
                   "name": "parseScalar",
                   "printedName": "parseScalar(from:)",
-                  "declKind": "Func",
-                  "usr": "s:s7UnicodeO5UTF32O6ParserV11parseScalar4fromAB11ParseResultOy_s15CollectionOfOneVys6UInt32VGGxz_tStRzAN7ElementRtzlF",
-                  "location": "",
-                  "moduleName": "Swift",
-                  "genericSig": "<I where I : IteratorProtocol, I.Element == Unicode.UTF32.Parser.Encoding.CodeUnit>",
-                  "mutating": true,
-                  "declAttributes": [
-                    "Inlinable"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "ParseResult",
                       "printedName": "Unicode.ParseResult<Unicode.UTF32.Parser.Encoding.EncodedScalar>",
-                      "usr": "s:s7UnicodeO11ParseResultO",
                       "children": [
                         {
                           "kind": "TypeNameAlias",
@@ -113742,7 +125722,6 @@
                               "kind": "TypeNominal",
                               "name": "CollectionOfOne",
                               "printedName": "CollectionOfOne<UInt32>",
-                              "usr": "s:s15CollectionOfOneV",
                               "children": [
                                 {
                                   "kind": "TypeNominal",
@@ -113750,29 +125729,44 @@
                                   "printedName": "UInt32",
                                   "usr": "s:s6UInt32V"
                                 }
-                              ]
+                              ],
+                              "usr": "s:s15CollectionOfOneV"
                             }
                           ]
                         }
-                      ]
+                      ],
+                      "usr": "s:s7UnicodeO11ParseResultO"
                     },
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "I"
                     }
-                  ]
+                  ],
+                  "declKind": "Func",
+                  "usr": "s:s7UnicodeO5UTF32O6ParserV11parseScalar4fromAB11ParseResultOy_s15CollectionOfOneVys6UInt32VGGxz_tStRzAN7ElementRtzlF",
+                  "moduleName": "Swift",
+                  "genericSig": "<I where I : IteratorProtocol, I.Element == Unicode.UTF32.Parser.Encoding.CodeUnit>",
+                  "declAttributes": [
+                    "Inlinable"
+                  ],
+                  "mutating": true
                 }
+              ],
+              "declKind": "Struct",
+              "usr": "s:s7UnicodeO5UTF32O6ParserV",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "FixedLayout"
+              ],
+              "conformingProtocols": [
+                "_UnicodeParser"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "ForwardParser",
               "printedName": "ForwardParser",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5UTF32O13ForwardParsera",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113780,16 +125774,15 @@
                   "printedName": "Unicode.UTF32.Parser",
                   "usr": "s:s7UnicodeO5UTF32O6ParserV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s7UnicodeO5UTF32O13ForwardParsera",
+              "moduleName": "Swift"
             },
             {
               "kind": "TypeAlias",
               "name": "ReverseParser",
               "printedName": "ReverseParser",
-              "declKind": "TypeAlias",
-              "usr": "s:s7UnicodeO5UTF32O13ReverseParsera",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113797,19 +125790,15 @@
                   "printedName": "Unicode.UTF32.Parser",
                   "usr": "s:s7UnicodeO5UTF32O6ParserV"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s7UnicodeO5UTF32O13ReverseParsera",
+              "moduleName": "Swift"
             },
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init()",
-              "declKind": "Constructor",
-              "usr": "s:s7UnicodeO5UTF32OADycfc",
-              "location": "",
-              "moduleName": "Swift",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113817,21 +125806,18 @@
                   "printedName": "Unicode.UTF32",
                   "usr": "s:s7UnicodeO5UTF32O"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s7UnicodeO5UTF32OADycfc",
+              "moduleName": "Swift",
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "Function",
               "name": "decode",
               "printedName": "decode(_:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF32O6decodeys0A14DecodingResultOxzStRzs6UInt32V7ElementRtzlF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<I where I : IteratorProtocol, I.Element == Unicode.UTF32.CodeUnit>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113844,20 +125830,20 @@
                   "name": "GenericTypeParam",
                   "printedName": "I"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF32O6decodeys0A14DecodingResultOxzStRzs6UInt32V7ElementRtzlF",
+              "moduleName": "Swift",
+              "genericSig": "<I where I : IteratorProtocol, I.Element == Unicode.UTF32.CodeUnit>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
               "kind": "Function",
               "name": "encode",
               "printedName": "encode(_:into:)",
-              "declKind": "Func",
-              "usr": "s:s7UnicodeO5UTF32O6encode_4intoyAB6ScalarV_ys6UInt32VXEtFZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -113874,9 +125860,6 @@
                   "kind": "TypeFunc",
                   "name": "Function",
                   "printedName": "(Unicode.UTF32.CodeUnit) -> Void",
-                  "typeAttributes": [
-                    "noescape"
-                  ],
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -113894,7 +125877,6 @@
                       "kind": "TypeNominal",
                       "name": "Paren",
                       "printedName": "(Unicode.UTF32.CodeUnit)",
-                      "usr": "s:s6UInt32V",
                       "children": [
                         {
                           "kind": "TypeNameAlias",
@@ -113909,28 +125891,49 @@
                             }
                           ]
                         }
-                      ]
+                      ],
+                      "usr": "s:s6UInt32V"
                     }
+                  ],
+                  "typeAttributes": [
+                    "noescape"
                   ]
                 }
+              ],
+              "declKind": "Func",
+              "usr": "s:s7UnicodeO5UTF32O6encode_4intoyAB6ScalarV_ys6UInt32VXEtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             }
+          ],
+          "declKind": "Enum",
+          "usr": "s:s7UnicodeO5UTF32O",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Frozen"
+          ],
+          "conformingProtocols": [
+            "Equatable",
+            "Hashable",
+            "_UnicodeEncoding",
+            "UnicodeCodec"
           ]
         }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s7UnicodeO",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Frozen"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "BidirectionalIndexable",
       "printedName": "BidirectionalIndexable",
-      "declKind": "TypeAlias",
-      "usr": "s:s22BidirectionalIndexablea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -113938,20 +125941,19 @@
           "printedName": "BidirectionalCollection",
           "usr": "s:SK"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s22BidirectionalIndexablea",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "IndexableBase",
       "printedName": "IndexableBase",
-      "declKind": "TypeAlias",
-      "usr": "s:s13IndexableBasea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -113959,20 +125961,19 @@
           "printedName": "Collection",
           "usr": "s:Sl"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s13IndexableBasea",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "Indexable",
       "printedName": "Indexable",
-      "declKind": "TypeAlias",
-      "usr": "s:s9Indexablea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -113980,20 +125981,19 @@
           "printedName": "Collection",
           "usr": "s:Sl"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s9Indexablea",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "MutableIndexable",
       "printedName": "MutableIndexable",
-      "declKind": "TypeAlias",
-      "usr": "s:s16MutableIndexablea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -114001,20 +126001,19 @@
           "printedName": "MutableCollection",
           "usr": "s:SM"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s16MutableIndexablea",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "RandomAccessIndexable",
       "printedName": "RandomAccessIndexable",
-      "declKind": "TypeAlias",
-      "usr": "s:s21RandomAccessIndexablea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -114022,20 +126021,19 @@
           "printedName": "RandomAccessCollection",
           "usr": "s:Sk"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s21RandomAccessIndexablea",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "RangeReplaceableIndexable",
       "printedName": "RangeReplaceableIndexable",
-      "declKind": "TypeAlias",
-      "usr": "s:s25RangeReplaceableIndexablea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -114043,20 +126041,19 @@
           "printedName": "RangeReplaceableCollection",
           "usr": "s:Sm"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s25RangeReplaceableIndexablea",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "EnumeratedIterator",
       "printedName": "EnumeratedIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s18EnumeratedIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Sequence>",
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -114064,20 +126061,20 @@
           "printedName": "EnumeratedSequence<T>.Iterator",
           "usr": "s:s18EnumeratedSequenceV8IteratorV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s18EnumeratedIteratora",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : Sequence>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "IteratorOverOne",
       "printedName": "IteratorOverOne",
-      "declKind": "TypeAlias",
-      "usr": "s:s15IteratorOverOnea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -114085,20 +126082,20 @@
           "printedName": "CollectionOfOne<T>.Iterator",
           "usr": "s:s15CollectionOfOneV8IteratorV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s15IteratorOverOnea",
+      "moduleName": "Swift",
+      "genericSig": "<T>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "EmptyIterator",
       "printedName": "EmptyIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s13EmptyIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -114106,21 +126103,20 @@
           "printedName": "EmptyCollection<T>.Iterator",
           "usr": "s:s15EmptyCollectionV8IteratorV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s13EmptyIteratora",
+      "moduleName": "Swift",
+      "genericSig": "<T>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "LazyFilterIterator",
       "printedName": "LazyFilterIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s18LazyFilterIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Sequence>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -114128,42 +126124,40 @@
           "printedName": "LazyFilterSequence<T>.Iterator",
           "usr": "s:s18LazyFilterSequenceV8IteratorV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s18LazyFilterIteratora",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : Sequence>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "LazyFilterIndex",
       "printedName": "LazyFilterIndex",
-      "declKind": "TypeAlias",
-      "usr": "s:s15LazyFilterIndexa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Base where Base : Collection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "DependentMember",
           "printedName": "Base.Index"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s15LazyFilterIndexa",
+      "moduleName": "Swift",
+      "genericSig": "<Base where Base : Collection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "LazyDropWhileIterator",
       "printedName": "LazyDropWhileIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s21LazyDropWhileIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Sequence>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -114171,21 +126165,20 @@
           "printedName": "LazyDropWhileSequence<T>.Iterator",
           "usr": "s:s21LazyDropWhileSequenceV8IteratorV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s21LazyDropWhileIteratora",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : Sequence>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "LazyDropWhileIndex",
       "printedName": "LazyDropWhileIndex",
-      "declKind": "TypeAlias",
-      "usr": "s:s18LazyDropWhileIndexa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Collection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -114193,79 +126186,76 @@
           "printedName": "LazyDropWhileCollection<T>.Index",
           "usr": "s:s23LazyDropWhileCollectionV5IndexV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s18LazyDropWhileIndexa",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : Collection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "LazyDropWhileBidirectionalCollection",
       "printedName": "LazyDropWhileBidirectionalCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s36LazyDropWhileBidirectionalCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "LazyDropWhileCollection",
           "printedName": "LazyDropWhileCollection<T>",
-          "usr": "s:s23LazyDropWhileCollectionV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s23LazyDropWhileCollectionV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s36LazyDropWhileBidirectionalCollectiona",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : BidirectionalCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "LazyFilterBidirectionalCollection",
       "printedName": "LazyFilterBidirectionalCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s33LazyFilterBidirectionalCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "LazyFilterCollection",
           "printedName": "LazyFilterCollection<T>",
-          "usr": "s:s20LazyFilterCollectionV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s20LazyFilterCollectionV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s33LazyFilterBidirectionalCollectiona",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : BidirectionalCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "LazyMapIterator",
       "printedName": "LazyMapIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s15LazyMapIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, E where T : Sequence>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -114273,27 +126263,25 @@
           "printedName": "LazyMapSequence<T, E>.Iterator",
           "usr": "s:s15LazyMapSequenceV8IteratorV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s15LazyMapIteratora",
+      "moduleName": "Swift",
+      "genericSig": "<T, E where T : Sequence>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "LazyMapBidirectionalCollection",
       "printedName": "LazyMapBidirectionalCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s30LazyMapBidirectionalCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, E where T : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "LazyMapCollection",
           "printedName": "LazyMapCollection<T, E>",
-          "usr": "s:s17LazyMapCollectionV",
           "children": [
             {
               "kind": "TypeNominal",
@@ -114305,29 +126293,28 @@
               "name": "GenericTypeParam",
               "printedName": "E"
             }
-          ]
+          ],
+          "usr": "s:s17LazyMapCollectionV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s30LazyMapBidirectionalCollectiona",
+      "moduleName": "Swift",
+      "genericSig": "<T, E where T : BidirectionalCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "LazyMapRandomAccessCollection",
       "printedName": "LazyMapRandomAccessCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s29LazyMapRandomAccessCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, E where T : RandomAccessCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "LazyMapCollection",
           "printedName": "LazyMapCollection<T, E>",
-          "usr": "s:s17LazyMapCollectionV",
           "children": [
             {
               "kind": "TypeNominal",
@@ -114339,81 +126326,79 @@
               "name": "GenericTypeParam",
               "printedName": "E"
             }
-          ]
+          ],
+          "usr": "s:s17LazyMapCollectionV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s29LazyMapRandomAccessCollectiona",
+      "moduleName": "Swift",
+      "genericSig": "<T, E where T : RandomAccessCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "LazyBidirectionalCollection",
       "printedName": "LazyBidirectionalCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s27LazyBidirectionalCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "LazyCollection",
           "printedName": "LazyCollection<T>",
-          "usr": "s:s14LazyCollectionV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s14LazyCollectionV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s27LazyBidirectionalCollectiona",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : BidirectionalCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "LazyRandomAccessCollection",
       "printedName": "LazyRandomAccessCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s26LazyRandomAccessCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : RandomAccessCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "LazyCollection",
           "printedName": "LazyCollection<T>",
-          "usr": "s:s14LazyCollectionV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s14LazyCollectionV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s26LazyRandomAccessCollectiona",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : RandomAccessCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "FlattenCollectionIndex",
       "printedName": "FlattenCollectionIndex",
-      "declKind": "TypeAlias",
-      "usr": "s:s22FlattenCollectionIndexa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Collection, T.Element : Collection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -114421,21 +126406,20 @@
           "printedName": "FlattenCollection<T>.Index",
           "usr": "s:s17FlattenCollectionV5IndexV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s22FlattenCollectionIndexa",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : Collection, T.Element : Collection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "FlattenBidirectionalCollectionIndex",
       "printedName": "FlattenBidirectionalCollectionIndex",
-      "declKind": "TypeAlias",
-      "usr": "s:s35FlattenBidirectionalCollectionIndexa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection, T.Element : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -114443,50 +126427,48 @@
           "printedName": "FlattenCollection<T>.Index",
           "usr": "s:s17FlattenCollectionV5IndexV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s35FlattenBidirectionalCollectionIndexa",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : BidirectionalCollection, T.Element : BidirectionalCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "FlattenBidirectionalCollection",
       "printedName": "FlattenBidirectionalCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s30FlattenBidirectionalCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection, T.Element : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "FlattenCollection",
           "printedName": "FlattenCollection<T>",
-          "usr": "s:s17FlattenCollectionV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s17FlattenCollectionV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s30FlattenBidirectionalCollectiona",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : BidirectionalCollection, T.Element : BidirectionalCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "JoinedIterator",
       "printedName": "JoinedIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s14JoinedIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Sequence, T.Element : Sequence>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -114494,20 +126476,20 @@
           "printedName": "JoinedSequence<T>.Iterator",
           "usr": "s:s14JoinedSequenceV8IteratorV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s14JoinedIteratora",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : Sequence, T.Element : Sequence>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "Zip2Iterator",
       "printedName": "Zip2Iterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s12Zip2Iteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, U where T : Sequence, U : Sequence>",
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -114515,21 +126497,20 @@
           "printedName": "Zip2Sequence<T, U>.Iterator",
           "usr": "s:s12Zip2SequenceV8IteratorV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s12Zip2Iteratora",
+      "moduleName": "Swift",
+      "genericSig": "<T, U where T : Sequence, U : Sequence>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "LazyPrefixWhileIterator",
       "printedName": "LazyPrefixWhileIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s23LazyPrefixWhileIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Sequence>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -114537,21 +126518,20 @@
           "printedName": "LazyPrefixWhileSequence<T>.Iterator",
           "usr": "s:s23LazyPrefixWhileSequenceV8IteratorV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s23LazyPrefixWhileIteratora",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : Sequence>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "LazyPrefixWhileIndex",
       "printedName": "LazyPrefixWhileIndex",
-      "declKind": "TypeAlias",
-      "usr": "s:s20LazyPrefixWhileIndexa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : Collection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -114559,484 +126539,468 @@
           "printedName": "LazyPrefixWhileCollection<T>.Index",
           "usr": "s:s25LazyPrefixWhileCollectionV5IndexV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s20LazyPrefixWhileIndexa",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : Collection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "LazyPrefixWhileBidirectionalCollection",
       "printedName": "LazyPrefixWhileBidirectionalCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s38LazyPrefixWhileBidirectionalCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "LazyPrefixWhileCollection",
           "printedName": "LazyPrefixWhileCollection<T>",
-          "usr": "s:s25LazyPrefixWhileCollectionV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s25LazyPrefixWhileCollectionV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s38LazyPrefixWhileBidirectionalCollectiona",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : BidirectionalCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "ReversedRandomAccessCollection",
       "printedName": "ReversedRandomAccessCollection",
-      "declKind": "TypeAlias",
-      "usr": "s:s30ReversedRandomAccessCollectiona",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : RandomAccessCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "ReversedCollection",
           "printedName": "ReversedCollection<T>",
-          "usr": "s:s18ReversedCollectionV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s18ReversedCollectionV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s30ReversedRandomAccessCollectiona",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : RandomAccessCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "ReversedIndex",
       "printedName": "ReversedIndex",
-      "declKind": "TypeAlias",
-      "usr": "s:s13ReversedIndexa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "ReversedCollection",
           "printedName": "ReversedCollection<T>",
-          "usr": "s:s18ReversedCollectionV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s18ReversedCollectionV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s13ReversedIndexa",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : BidirectionalCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "BidirectionalSlice",
       "printedName": "BidirectionalSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s18BidirectionalSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Slice",
           "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s5SliceV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s18BidirectionalSlicea",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : BidirectionalCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "RandomAccessSlice",
       "printedName": "RandomAccessSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s17RandomAccessSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : RandomAccessCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Slice",
           "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s5SliceV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s17RandomAccessSlicea",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : RandomAccessCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "RangeReplaceableSlice",
       "printedName": "RangeReplaceableSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s21RangeReplaceableSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : RangeReplaceableCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Slice",
           "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s5SliceV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s21RangeReplaceableSlicea",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : RangeReplaceableCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "RangeReplaceableBidirectionalSlice",
       "printedName": "RangeReplaceableBidirectionalSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s34RangeReplaceableBidirectionalSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection, T : RangeReplaceableCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Slice",
           "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s5SliceV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s34RangeReplaceableBidirectionalSlicea",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : BidirectionalCollection, T : RangeReplaceableCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "RangeReplaceableRandomAccessSlice",
       "printedName": "RangeReplaceableRandomAccessSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s33RangeReplaceableRandomAccessSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : RandomAccessCollection, T : RangeReplaceableCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Slice",
           "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s5SliceV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s33RangeReplaceableRandomAccessSlicea",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : RandomAccessCollection, T : RangeReplaceableCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "MutableSlice",
       "printedName": "MutableSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s12MutableSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : MutableCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Slice",
           "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s5SliceV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s12MutableSlicea",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : MutableCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "MutableBidirectionalSlice",
       "printedName": "MutableBidirectionalSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s25MutableBidirectionalSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection, T : MutableCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Slice",
           "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s5SliceV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s25MutableBidirectionalSlicea",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : BidirectionalCollection, T : MutableCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "MutableRandomAccessSlice",
       "printedName": "MutableRandomAccessSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s24MutableRandomAccessSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : MutableCollection, T : RandomAccessCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Slice",
           "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s5SliceV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s24MutableRandomAccessSlicea",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : MutableCollection, T : RandomAccessCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "MutableRangeReplaceableSlice",
       "printedName": "MutableRangeReplaceableSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s28MutableRangeReplaceableSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : MutableCollection, T : RangeReplaceableCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Slice",
           "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s5SliceV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s28MutableRangeReplaceableSlicea",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : MutableCollection, T : RangeReplaceableCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "MutableRangeReplaceableBidirectionalSlice",
       "printedName": "MutableRangeReplaceableBidirectionalSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s41MutableRangeReplaceableBidirectionalSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection, T : MutableCollection, T : RangeReplaceableCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Slice",
           "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s5SliceV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s41MutableRangeReplaceableBidirectionalSlicea",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : BidirectionalCollection, T : MutableCollection, T : RangeReplaceableCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "MutableRangeReplaceableRandomAccessSlice",
       "printedName": "MutableRangeReplaceableRandomAccessSlice",
-      "declKind": "TypeAlias",
-      "usr": "s:s40MutableRangeReplaceableRandomAccessSlicea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : MutableCollection, T : RandomAccessCollection, T : RangeReplaceableCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Slice",
           "printedName": "Slice<T>",
-          "usr": "s:s5SliceV",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:s5SliceV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s40MutableRangeReplaceableRandomAccessSlicea",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : MutableCollection, T : RandomAccessCollection, T : RangeReplaceableCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "DefaultBidirectionalIndices",
       "printedName": "DefaultBidirectionalIndices",
-      "declKind": "TypeAlias",
-      "usr": "s:s27DefaultBidirectionalIndicesa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : BidirectionalCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "DefaultIndices",
           "printedName": "DefaultIndices<T>",
-          "usr": "s:SI",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:SI"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s27DefaultBidirectionalIndicesa",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : BidirectionalCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "DefaultRandomAccessIndices",
       "printedName": "DefaultRandomAccessIndices",
-      "declKind": "TypeAlias",
-      "usr": "s:s26DefaultRandomAccessIndicesa",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T where T : RandomAccessCollection>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "DefaultIndices",
           "printedName": "DefaultIndices<T>",
-          "usr": "s:SI",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "T"
             }
-          ]
+          ],
+          "usr": "s:SI"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s26DefaultRandomAccessIndicesa",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : RandomAccessCollection>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "NilLiteralConvertible",
       "printedName": "NilLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s21NilLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -115044,20 +127008,19 @@
           "printedName": "ExpressibleByNilLiteral",
           "usr": "s:s23ExpressibleByNilLiteralP"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s21NilLiteralConvertiblea",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "IntegerLiteralConvertible",
       "printedName": "IntegerLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s25IntegerLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -115065,20 +127028,19 @@
           "printedName": "ExpressibleByIntegerLiteral",
           "usr": "s:s27ExpressibleByIntegerLiteralP"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s25IntegerLiteralConvertiblea",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "FloatLiteralConvertible",
       "printedName": "FloatLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s23FloatLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -115086,20 +127048,19 @@
           "printedName": "ExpressibleByFloatLiteral",
           "usr": "s:s25ExpressibleByFloatLiteralP"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s23FloatLiteralConvertiblea",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "BooleanLiteralConvertible",
       "printedName": "BooleanLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s25BooleanLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -115107,20 +127068,19 @@
           "printedName": "ExpressibleByBooleanLiteral",
           "usr": "s:s27ExpressibleByBooleanLiteralP"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s25BooleanLiteralConvertiblea",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "UnicodeScalarLiteralConvertible",
       "printedName": "UnicodeScalarLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s31UnicodeScalarLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -115128,20 +127088,19 @@
           "printedName": "ExpressibleByUnicodeScalarLiteral",
           "usr": "s:s33ExpressibleByUnicodeScalarLiteralP"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s31UnicodeScalarLiteralConvertiblea",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "ExtendedGraphemeClusterLiteralConvertible",
       "printedName": "ExtendedGraphemeClusterLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s41ExtendedGraphemeClusterLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -115149,20 +127108,19 @@
           "printedName": "ExpressibleByExtendedGraphemeClusterLiteral",
           "usr": "s:s43ExpressibleByExtendedGraphemeClusterLiteralP"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s41ExtendedGraphemeClusterLiteralConvertiblea",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "StringLiteralConvertible",
       "printedName": "StringLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s24StringLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -115170,20 +127128,19 @@
           "printedName": "ExpressibleByStringLiteral",
           "usr": "s:s26ExpressibleByStringLiteralP"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s24StringLiteralConvertiblea",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "ArrayLiteralConvertible",
       "printedName": "ArrayLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s23ArrayLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -115191,20 +127148,19 @@
           "printedName": "ExpressibleByArrayLiteral",
           "usr": "s:s25ExpressibleByArrayLiteralP"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s23ArrayLiteralConvertiblea",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "DictionaryLiteralConvertible",
       "printedName": "DictionaryLiteralConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s28DictionaryLiteralConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -115212,20 +127168,19 @@
           "printedName": "ExpressibleByDictionaryLiteral",
           "usr": "s:s30ExpressibleByDictionaryLiteralP"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s28DictionaryLiteralConvertiblea",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "StringInterpolationConvertible",
       "printedName": "StringInterpolationConvertible",
-      "declKind": "TypeAlias",
-      "usr": "s:s30StringInterpolationConvertiblea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNameAlias",
@@ -115240,115 +127195,72 @@
             }
           ]
         }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "BitwiseOperations",
-      "printedName": "BitwiseOperations",
+      ],
       "declKind": "TypeAlias",
-      "usr": "s:s17BitwiseOperationsa",
-      "location": "",
+      "usr": "s:s30StringInterpolationConvertiblea",
       "moduleName": "Swift",
       "deprecated": true,
       "declAttributes": [
         "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "_BitwiseOperations",
-          "printedName": "_BitwiseOperations",
-          "usr": "s:s18_BitwiseOperationsP"
-        }
       ]
     },
     {
       "kind": "TypeAlias",
-      "name": "Integer",
-      "printedName": "Integer",
-      "declKind": "TypeAlias",
-      "usr": "s:s7Integera",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Available"
-      ],
+      "name": "ClosedRangeIndex",
+      "printedName": "ClosedRangeIndex",
       "children": [
         {
           "kind": "TypeNominal",
-          "name": "BinaryInteger",
-          "printedName": "BinaryInteger",
-          "usr": "s:Sz"
+          "name": "Index",
+          "printedName": "ClosedRange<T>.Index",
+          "usr": "s:SNsSxRzSZ6StrideRpzrlE5IndexO"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s16ClosedRangeIndexa",
+      "moduleName": "Swift",
+      "genericSig": "<T where T : Strideable, T.Stride : SignedInteger>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
-      "name": "IntegerArithmetic",
-      "printedName": "IntegerArithmetic",
-      "declKind": "TypeAlias",
-      "usr": "s:s17IntegerArithmetica",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Available"
-      ],
+      "name": "DictionaryLiteral",
+      "printedName": "DictionaryLiteral",
       "children": [
         {
           "kind": "TypeNominal",
-          "name": "BinaryInteger",
-          "printedName": "BinaryInteger",
-          "usr": "s:Sz"
+          "name": "KeyValuePairs",
+          "printedName": "KeyValuePairs<Key, Value>",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Key"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Value"
+            }
+          ],
+          "usr": "s:s13KeyValuePairsV"
         }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "SignedNumber",
-      "printedName": "SignedNumber",
+      ],
       "declKind": "TypeAlias",
-      "usr": "s:s12SignedNumbera",
-      "location": "",
+      "usr": "s:s17DictionaryLiterala",
       "moduleName": "Swift",
+      "genericSig": "<Key, Value>",
       "declAttributes": [
         "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ProtocolComposition",
-          "printedName": "Comparable & SignedNumeric"
-        }
-      ]
-    },
-    {
-      "kind": "TypeAlias",
-      "name": "AbsoluteValuable",
-      "printedName": "AbsoluteValuable",
-      "declKind": "TypeAlias",
-      "usr": "s:s16AbsoluteValuablea",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Available"
-      ],
-      "children": [
-        {
-          "kind": "TypeNominal",
-          "name": "ProtocolComposition",
-          "printedName": "Comparable & SignedNumeric"
-        }
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "UTF8",
       "printedName": "UTF8",
-      "declKind": "TypeAlias",
-      "usr": "s:s4UTF8a",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -115356,16 +127268,15 @@
           "printedName": "Unicode.UTF8",
           "usr": "s:s7UnicodeO4UTF8O"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s4UTF8a",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "UTF16",
       "printedName": "UTF16",
-      "declKind": "TypeAlias",
-      "usr": "s:s5UTF16a",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -115373,16 +127284,15 @@
           "printedName": "Unicode.UTF16",
           "usr": "s:s7UnicodeO5UTF16O"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s5UTF16a",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "UTF32",
       "printedName": "UTF32",
-      "declKind": "TypeAlias",
-      "usr": "s:s5UTF32a",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -115390,16 +127300,15 @@
           "printedName": "Unicode.UTF32",
           "usr": "s:s7UnicodeO5UTF32O"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s5UTF32a",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "UnicodeScalar",
       "printedName": "UnicodeScalar",
-      "declKind": "TypeAlias",
-      "usr": "s:Sc",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "TypeNominal",
@@ -115407,21 +127316,15 @@
           "printedName": "Unicode.Scalar",
           "usr": "s:s7UnicodeO6ScalarV"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:Sc",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeAlias",
       "name": "UnsafeBufferPointerIterator",
       "printedName": "UnsafeBufferPointerIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s27UnsafeBufferPointerIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -115429,21 +127332,20 @@
           "printedName": "UnsafeBufferPointer<T>.Iterator",
           "usr": "s:SR8IteratorV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s27UnsafeBufferPointerIteratora",
+      "moduleName": "Swift",
+      "genericSig": "<T>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "UnsafeRawBufferPointerIterator",
       "printedName": "UnsafeRawBufferPointerIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s30UnsafeRawBufferPointerIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -115451,21 +127353,20 @@
           "printedName": "UnsafeBufferPointer<T>.Iterator",
           "usr": "s:SR8IteratorV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s30UnsafeRawBufferPointerIteratora",
+      "moduleName": "Swift",
+      "genericSig": "<T>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "UnsafeMutableRawBufferPointerIterator",
       "printedName": "UnsafeMutableRawBufferPointerIterator",
-      "declKind": "TypeAlias",
-      "usr": "s:s37UnsafeMutableRawBufferPointerIteratora",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -115473,20 +127374,20 @@
           "printedName": "UnsafeBufferPointer<T>.Iterator",
           "usr": "s:SR8IteratorV"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s37UnsafeMutableRawBufferPointerIteratora",
+      "moduleName": "Swift",
+      "genericSig": "<T>",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "PlaygroundQuickLook",
       "printedName": "PlaygroundQuickLook",
-      "declKind": "TypeAlias",
-      "usr": "s:s19PlaygroundQuickLooka",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -115494,20 +127395,19 @@
           "printedName": "_PlaygroundQuickLook",
           "usr": "s:s20_PlaygroundQuickLookO"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s19PlaygroundQuickLooka",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "CustomPlaygroundQuickLookable",
       "printedName": "CustomPlaygroundQuickLookable",
-      "declKind": "TypeAlias",
-      "usr": "s:s29CustomPlaygroundQuickLookablea",
-      "location": "",
-      "moduleName": "Swift",
-      "deprecated": true,
-      "declAttributes": [
-        "Available"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -115515,136 +127415,118 @@
           "printedName": "_CustomPlaygroundQuickLookable",
           "usr": "s:s30_CustomPlaygroundQuickLookableP"
         }
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s29CustomPlaygroundQuickLookablea",
+      "moduleName": "Swift",
+      "deprecated": true,
+      "declAttributes": [
+        "Available"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "CollectionOfOne",
       "printedName": "CollectionOfOne",
-      "declKind": "Struct",
-      "usr": "s:s15CollectionOfOneV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "RandomAccessCollection",
-        "MutableCollection",
-        "BidirectionalCollection",
-        "Collection",
-        "Sequence",
-        "CustomDebugStringConvertible",
-        "CustomReflectable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s15CollectionOfOneVyAByxGxcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "CollectionOfOne",
               "printedName": "CollectionOfOne<Element>",
-              "usr": "s:s15CollectionOfOneV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s15CollectionOfOneV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s15CollectionOfOneVyAByxGxcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s15CollectionOfOneV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "conformingProtocols": [
-            "IteratorProtocol"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s15CollectionOfOneV8IteratorV4nextxSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s15CollectionOfOneV8IteratorV4nextxSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<Element>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s15CollectionOfOneV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s15CollectionOfOneV8IteratorV7Elementa",
+              "moduleName": "Swift",
+              "genericSig": "<Element>",
+              "implicit": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s15CollectionOfOneV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s15CollectionOfOneV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -115652,23 +127534,21 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15CollectionOfOneV5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s15CollectionOfOneV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Range",
               "printedName": "Range<Int>",
-              "usr": "s:Sn",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -115676,54 +127556,51 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "usr": "s:Sn"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15CollectionOfOneV7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s15CollectionOfOneV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Slice",
               "printedName": "Slice<CollectionOfOne<Element>>",
-              "usr": "s:s5SliceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "CollectionOfOne",
                   "printedName": "CollectionOfOne<Element>",
-                  "usr": "s:s15CollectionOfOneV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s15CollectionOfOneV"
                 }
-              ]
+              ],
+              "usr": "s:s5SliceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15CollectionOfOneV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s15CollectionOfOneV10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -115742,11 +127619,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15CollectionOfOneV10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -115761,21 +127633,24 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15CollectionOfOneV10startIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15CollectionOfOneV10startIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s15CollectionOfOneV8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -115794,11 +127669,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15CollectionOfOneV8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -115813,22 +127683,24 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15CollectionOfOneV8endIndexSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15CollectionOfOneV8endIndexSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s15CollectionOfOneV5index5afterS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -115856,20 +127728,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15CollectionOfOneV5index5afterS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s15CollectionOfOneV5index6beforeS2i_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -115897,20 +127768,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15CollectionOfOneV5index6beforeS2i_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s15CollectionOfOneV12makeIteratorAB0E0Vyx_GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -115918,19 +127788,102 @@
               "printedName": "CollectionOfOne<Element>.Iterator",
               "usr": "s:s15CollectionOfOneV8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s15CollectionOfOneV12makeIteratorAB0E0Vyx_GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Element"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s15CollectionOfOneVyxSicip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "SubSequence",
+              "printedName": "CollectionOfOne<Element>.SubSequence",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Slice",
+                  "printedName": "Slice<CollectionOfOne<τ_0_0>>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "CollectionOfOne",
+                      "printedName": "CollectionOfOne<τ_0_0>",
+                      "children": [
+                        {
+                          "kind": "TypeNominal",
+                          "name": "GenericTypeParam",
+                          "printedName": "τ_0_0"
+                        }
+                      ],
+                      "usr": "s:s15CollectionOfOneV"
+                    }
+                  ],
+                  "usr": "s:s5SliceV"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<Int>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s15CollectionOfOneVys5SliceVyAByxGGSnySiGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "hasSetter": true
+        },
+        {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s15CollectionOfOneV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -115942,11 +127895,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15CollectionOfOneV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -115954,35 +127902,41 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15CollectionOfOneV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s15CollectionOfOneV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s15CollectionOfOneV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s15CollectionOfOneV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         },
         {
           "kind": "Var",
           "name": "debugDescription",
           "printedName": "debugDescription",
-          "declKind": "Var",
-          "usr": "s:s15CollectionOfOneV16debugDescriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -115994,11 +127948,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15CollectionOfOneV16debugDescriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -116006,18 +127955,21 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15CollectionOfOneV16debugDescriptionSSvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s15CollectionOfOneV16debugDescriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s15CollectionOfOneV12customMirrors0E0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -116029,11 +127981,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s15CollectionOfOneV12customMirrors0E0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -116041,87 +127988,89 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s15CollectionOfOneV12customMirrors0E0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s15CollectionOfOneV12customMirrors0E0Vvp",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s15CollectionOfOneV",
+      "moduleName": "Swift",
+      "genericSig": "<Element>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "RandomAccessCollection",
+        "MutableCollection",
+        "BidirectionalCollection",
+        "Collection",
+        "Sequence",
+        "CustomDebugStringConvertible",
+        "CustomReflectable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AnyIterator",
       "printedName": "AnyIterator",
-      "declKind": "Struct",
-      "usr": "s:s11AnyIteratorV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "IteratorProtocol",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s11AnyIteratorVyAByxGqd__c7ElementQyd__RszStRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, I where Element == I.Element, I : IteratorProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyIterator",
               "printedName": "AnyIterator<Element>",
-              "usr": "s:s11AnyIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnyIteratorV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "I"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s11AnyIteratorVyAByxGqd__c7ElementQyd__RszStRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Element, I where Element == I.Element, I : IteratorProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s11AnyIteratorVyAByxGxSgyccfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyIterator",
               "printedName": "AnyIterator<Element>",
-              "usr": "s:s11AnyIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnyIteratorV"
             },
             {
               "kind": "TypeFunc",
@@ -116132,7 +128081,6 @@
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "AnyIterator<Element>.Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -116146,7 +128094,8 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -116155,146 +128104,144 @@
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s11AnyIteratorVyAByxGxSgyccfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s11AnyIteratorV4nextxSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnyIteratorV4nextxSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s11AnyIteratorV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s11AnyIteratorV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s11AnyIteratorV0B0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyIterator",
               "printedName": "AnyIterator<Element>",
-              "usr": "s:s11AnyIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnyIteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s11AnyIteratorV0B0a",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s11AnyIteratorV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s11AnyIteratorV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s11AnyIteratorV",
+      "moduleName": "Swift",
+      "genericSig": "<Element>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol",
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AnySequence",
       "printedName": "AnySequence",
-      "declKind": "Struct",
-      "usr": "s:s11AnySequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s11AnySequenceVyAByxGqd__ycc7ElementQyd__RszStRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, I where Element == I.Element, I : IteratorProtocol>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeFunc",
@@ -116313,121 +128260,117 @@
                 }
               ]
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s11AnySequenceVyAByxGqd__ycc7ElementQyd__RszStRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Element, I where Element == I.Element, I : IteratorProtocol>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s11AnySequenceV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyIterator",
               "printedName": "AnyIterator<Element>",
-              "usr": "s:s11AnyIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnyIteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s11AnySequenceV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s11AnySequenceVyAByxGqd__c7ElementQyd__RszSTRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "S"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s11AnySequenceVyAByxGqd__c7ElementQyd__RszSTRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Element, S where Element == S.Element, S : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s11AnySequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s11AnySequenceV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s11AnySequenceV03SubB0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s11AnySequenceV03SubB0a",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV12makeIterators0aD0VyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable",
-            "Inline"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -116438,30 +128381,31 @@
                   "kind": "TypeNominal",
                   "name": "AnyIterator",
                   "printedName": "AnyIterator<τ_0_0>",
-                  "usr": "s:s11AnyIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s11AnyIteratorV"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV12makeIterators0aD0VyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable",
+            "Inline"
           ]
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s11AnySequenceV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -116473,11 +128417,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11AnySequenceV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -116485,45 +128424,42 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11AnySequenceV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s11AnySequenceV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV3mapySayqd__Gqd__xKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, T>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[T]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> T",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -116542,45 +128478,44 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV3mapySayqd__Gqd__xKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, T>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV6filterySayxGSbxKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -116600,24 +128535,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV6filterySayxGSbxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "forEach",
           "printedName": "forEach(_:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV7forEachyyyxKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -116628,9 +128565,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -116656,45 +128590,44 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV7forEachyyyxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV4drop5whileAByxGSbxKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -116714,35 +128647,39 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV4drop5whileAByxGSbxKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV9dropFirstyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
@@ -116750,33 +128687,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV9dropFirstyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV8dropLastyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
@@ -116784,43 +128720,37 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV8dropLastyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV6prefix5whileAByxGSbxKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -116840,35 +128770,39 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV6prefix5whileAByxGSbxKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(_:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV6prefixyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
@@ -116876,33 +128810,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV6prefixyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV6suffixyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             },
             {
               "kind": "TypeNominal",
@@ -116910,43 +128843,40 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV6suffixyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(maxSplits:omittingEmptySubsequences:whereSeparator:)",
-          "declKind": "Func",
-          "usr": "s:s11AnySequenceV5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAByxGGSi_S2bxKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[AnySequence<Element>]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnySequence",
                   "printedName": "AnySequence<Element>",
-                  "usr": "s:s11AnySequenceV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s11AnySequenceV"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -116966,9 +128896,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -116988,40 +128915,43 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s11AnySequenceV5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAByxGGSi_S2bxKXEtKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s11AnySequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<Element>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AnyIndex",
       "printedName": "AnyIndex",
-      "declKind": "Struct",
-      "usr": "s:s8AnyIndexV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "Comparable",
-        "Equatable"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s8AnyIndexVyABxcSLRzlufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<BaseIndex where BaseIndex : Comparable>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -117034,41 +128964,100 @@
               "name": "GenericTypeParam",
               "printedName": "BaseIndex"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s8AnyIndexVyABxcSLRzlufc",
+          "moduleName": "Swift",
+          "genericSig": "<BaseIndex where BaseIndex : Comparable>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "==",
+          "printedName": "==(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s8AnyIndexV2eeoiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Function",
+          "name": "<",
+          "printedName": "<(_:_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Bool",
+              "printedName": "Bool",
+              "usr": "s:Sb"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyIndex",
+              "printedName": "AnyIndex",
+              "usr": "s:s8AnyIndexV"
+            }
+          ],
+          "declKind": "Func",
+          "usr": "s:s8AnyIndexV1loiySbAB_ABtFZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "Inlinable"
           ]
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s8AnyIndexV",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Comparable",
+        "Equatable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AnyCollection",
       "printedName": "AnyCollection",
-      "declKind": "Struct",
-      "usr": "s:s13AnyCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "Collection",
-        "Sequence",
-        "_AnyCollectionProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV12makeIterators0aD0VyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable",
-            "Inline"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -117079,30 +129068,31 @@
                   "kind": "TypeNominal",
                   "name": "AnyIterator",
                   "printedName": "AnyIterator<τ_0_0>",
-                  "usr": "s:s11AnyIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s11AnyIteratorV"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV12makeIterators0aD0VyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable",
+            "Inline"
           ]
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s13AnyCollectionV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -117114,11 +129104,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13AnyCollectionV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -117126,45 +129111,42 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13AnyCollectionV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13AnyCollectionV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV3mapySayqd__Gqd__xKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, T>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[T]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(AnyCollection<Element>.Element) throws -> T",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -117190,30 +129172,31 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV3mapySayqd__Gqd__xKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, T>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV6filterySayxGSbxKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[AnyCollection<Element>.Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -117227,15 +129210,13 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(AnyCollection<Element>.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -117262,24 +129243,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV6filterySayxGSbxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "forEach",
           "printedName": "forEach(_:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV7forEachyyyxKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -117290,9 +129273,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(AnyCollection<Element>.Element) throws -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -117325,30 +129305,31 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV7forEachyyyxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV4drop5whileAByxGSbxKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
               "printedName": "AnyCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s13AnyCollectionV",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -117362,15 +129343,13 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(AnyCollection<Element>.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -117397,28 +129376,31 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV4drop5whileAByxGSbxKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV9dropFirstyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
               "printedName": "AnyCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s13AnyCollectionV",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -117432,7 +129414,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -117440,26 +129423,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV9dropFirstyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV8dropLastyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
               "printedName": "AnyCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s13AnyCollectionV",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -117473,7 +129454,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -117481,28 +129463,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV8dropLastyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV6prefix5whileAByxGSbxKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
               "printedName": "AnyCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s13AnyCollectionV",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -117516,15 +129494,13 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(AnyCollection<Element>.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -117551,28 +129527,31 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV6prefix5whileAByxGSbxKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(_:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV6prefixyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
               "printedName": "AnyCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s13AnyCollectionV",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -117586,7 +129565,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -117594,26 +129574,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV6prefixyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV6suffixyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
               "printedName": "AnyCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s13AnyCollectionV",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -117627,7 +129605,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -117635,34 +129614,29 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV6suffixyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(maxSplits:omittingEmptySubsequences:whereSeparator:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAByxGGSi_S2bxKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[AnyCollection<AnyCollection<Element>.Element>]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnyCollection",
                   "printedName": "AnyCollection<AnyCollection<Element>.Element>",
-                  "usr": "s:s13AnyCollectionV",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -117676,9 +129650,11 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:s13AnyCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -117698,9 +129674,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(AnyCollection<Element>.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -117727,77 +129700,82 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAByxGGSi_S2bxKXEtKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s13AnyCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DefaultIndices",
               "printedName": "DefaultIndices<AnyCollection<Element>>",
-              "usr": "s:SI",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnyCollection",
                   "printedName": "AnyCollection<Element>",
-                  "usr": "s:s13AnyCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s13AnyCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:SI"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s13AnyCollectionV7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s13AnyCollectionV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyIterator",
               "printedName": "AnyIterator<Element>",
-              "usr": "s:s11AnyIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnyIteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s13AnyCollectionV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s13AnyCollectionV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -117805,97 +129783,90 @@
               "printedName": "AnyIndex",
               "usr": "s:s8AnyIndexV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s13AnyCollectionV5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s13AnyCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
               "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s13AnyCollectionV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13AnyCollectionVyAByxGqd__c7ElementQyd__RszSlRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, C where Element == C.Element, C : Collection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
               "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "C"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13AnyCollectionVyAByxGqd__c7ElementQyd__RszSlRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Element, C where Element == C.Element, C : Collection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13AnyCollectionVyAByxGACcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
               "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
               "printedName": "AnyCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s13AnyCollectionV",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -117909,74 +129880,72 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13AnyCollectionVyAByxGACcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13AnyCollectionVyAByxGqd__c7ElementQyd__RszSKRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, C where Element == C.Element, C : BidirectionalCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
               "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "C"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13AnyCollectionVyAByxGqd__c7ElementQyd__RszSKRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Element, C where Element == C.Element, C : BidirectionalCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13AnyCollectionVyAByxGs0a13BidirectionalB0VyxGcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
               "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
               "printedName": "AnyBidirectionalCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -117990,74 +129959,72 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13AnyCollectionVyAByxGs0a13BidirectionalB0VyxGcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13AnyCollectionVyAByxGqd__c7ElementQyd__RszSkRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, C where Element == C.Element, C : RandomAccessCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
               "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "C"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13AnyCollectionVyAByxGqd__c7ElementQyd__RszSkRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Element, C where Element == C.Element, C : RandomAccessCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s13AnyCollectionVyAByxGs0a12RandomAccessB0VyxGcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
               "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
               "printedName": "AnyRandomAccessCollection<AnyCollection<Element>.Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -118071,21 +130038,22 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s13AnyCollectionVyAByxGs0a12RandomAccessB0VyxGcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s13AnyCollectionV10startIndexs0aD0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -118104,11 +130072,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13AnyCollectionV10startIndexs0aD0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -118123,21 +130086,24 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13AnyCollectionV10startIndexs0aD0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13AnyCollectionV10startIndexs0aD0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s13AnyCollectionV8endIndexs0aD0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -118156,11 +130122,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13AnyCollectionV8endIndexs0aD0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -118175,22 +130136,111 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13AnyCollectionV8endIndexs0aD0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13AnyCollectionV8endIndexs0aD0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Element"
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "AnyCollection<Element>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "AnyIndex",
+                  "printedName": "AnyIndex",
+                  "usr": "s:s8AnyIndexV"
+                }
               ]
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s13AnyCollectionVyxs0A5IndexVcip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "SubSequence",
+              "printedName": "AnyCollection<Element>.SubSequence",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "AnyCollection",
+                  "printedName": "AnyCollection<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:s13AnyCollectionV"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<AnyCollection<Element>.Index>",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "AnyCollection<Element>.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "AnyIndex",
+                      "printedName": "AnyIndex",
+                      "usr": "s:s8AnyIndexV"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s13AnyCollectionVyAByxGSnys0A5IndexVGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV5index5afters0A5IndexVAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -118218,20 +130268,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV5index5afters0A5IndexVAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV9formIndex5afterys0aD0Vz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -118251,20 +130300,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV9formIndex5afterys0aD0Vz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV5index_8offsetBys0A5IndexVAF_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -118298,26 +130346,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV5index_8offsetBys0A5IndexVAF_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV5index_8offsetBy07limitedE0s0A5IndexVSgAG_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "AnyCollection<Element>.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -118332,7 +130378,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -118366,20 +130413,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV5index_8offsetBy07limitedE0s0A5IndexVSgAG_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV9formIndex_8offsetByys0aD0Vz_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -118405,20 +130451,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV9formIndex_8offsetByys0aD0Vz_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV9formIndex_8offsetBy07limitedF0Sbs0aD0Vz_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -118458,20 +130503,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV9formIndex_8offsetBy07limitedF0Sbs0aD0Vz_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s13AnyCollectionV8distance4from2toSis0A5IndexV_AGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -118505,19 +130549,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s13AnyCollectionV8distance4from2toSis0A5IndexV_AGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s13AnyCollectionV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -118529,11 +130573,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13AnyCollectionV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -118541,113 +130580,110 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13AnyCollectionV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13AnyCollectionV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "first",
           "printedName": "first",
-          "declKind": "Var",
-          "usr": "s:s13AnyCollectionV5firstxSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s13AnyCollectionV5firstxSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s13AnyCollectionV5firstxSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s13AnyCollectionV5firstxSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s13AnyCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s13AnyCollectionV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s13AnyCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<Element>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Collection",
+        "Sequence",
+        "_AnyCollectionProtocol"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AnyBidirectionalCollection",
       "printedName": "AnyBidirectionalCollection",
-      "declKind": "Struct",
-      "usr": "s:s26AnyBidirectionalCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "BidirectionalCollection",
-        "Collection",
-        "Sequence",
-        "_AnyCollectionProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV12makeIterators0aE0VyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable",
-            "Inline"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -118658,30 +130694,31 @@
                   "kind": "TypeNominal",
                   "name": "AnyIterator",
                   "printedName": "AnyIterator<τ_0_0>",
-                  "usr": "s:s11AnyIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s11AnyIteratorV"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV12makeIterators0aE0VyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable",
+            "Inline"
           ]
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s26AnyBidirectionalCollectionV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -118693,11 +130730,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s26AnyBidirectionalCollectionV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -118705,45 +130737,42 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s26AnyBidirectionalCollectionV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s26AnyBidirectionalCollectionV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV3mapySayqd__Gqd__xKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, T>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[T]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> T",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -118762,45 +130791,44 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV3mapySayqd__Gqd__xKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, T>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV6filterySayxGSbxKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -118820,24 +130848,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV6filterySayxGSbxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "forEach",
           "printedName": "forEach(_:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV7forEachyyyxKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -118848,9 +130878,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -118876,45 +130903,44 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV7forEachyyyxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV4drop5whileAByxGSbxKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
               "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -118934,35 +130960,39 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV4drop5whileAByxGSbxKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV9dropFirstyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
               "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -118970,33 +131000,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV9dropFirstyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV8dropLastyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
               "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -119004,43 +131033,37 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV8dropLastyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV6prefix5whileAByxGSbxKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
               "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -119060,35 +131083,39 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV6prefix5whileAByxGSbxKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(_:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV6prefixyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
               "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -119096,33 +131123,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV6prefixyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV6suffixyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
               "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -119130,43 +131156,40 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV6suffixyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(maxSplits:omittingEmptySubsequences:whereSeparator:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAByxGGSi_S2bxKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[AnyBidirectionalCollection<Element>]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnyBidirectionalCollection",
                   "printedName": "AnyBidirectionalCollection<Element>",
-                  "usr": "s:s26AnyBidirectionalCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s26AnyBidirectionalCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -119186,9 +131209,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -119208,77 +131228,82 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAByxGGSi_S2bxKXEtKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s26AnyBidirectionalCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DefaultIndices",
               "printedName": "DefaultIndices<AnyBidirectionalCollection<Element>>",
-              "usr": "s:SI",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnyBidirectionalCollection",
                   "printedName": "AnyBidirectionalCollection<Element>",
-                  "usr": "s:s26AnyBidirectionalCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s26AnyBidirectionalCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:SI"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s26AnyBidirectionalCollectionV7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s26AnyBidirectionalCollectionV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyIterator",
               "printedName": "AnyIterator<Element>",
-              "usr": "s:s11AnyIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnyIteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s26AnyBidirectionalCollectionV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s26AnyBidirectionalCollectionV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -119286,241 +131311,232 @@
               "printedName": "AnyIndex",
               "usr": "s:s8AnyIndexV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s26AnyBidirectionalCollectionV5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s26AnyBidirectionalCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
               "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s26AnyBidirectionalCollectionV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "AnyBidirectionalCollection",
+              "printedName": "AnyBidirectionalCollection<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            }
+          ],
           "declKind": "Constructor",
           "usr": "s:s26AnyBidirectionalCollectionVyAByxGqd__c7ElementQyd__RszSKRd__lufc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Element, C where Element == C.Element, C : BidirectionalCollection>",
           "declAttributes": [
             "Inlinable"
-          ],
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
               "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "AnyBidirectionalCollection",
+              "printedName": "AnyBidirectionalCollection<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
+            }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s26AnyBidirectionalCollectionVyAByxGACcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Constructor",
+          "name": "init",
+          "printedName": "init(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "AnyBidirectionalCollection",
+              "printedName": "AnyBidirectionalCollection<Element>",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "GenericTypeParam",
+                  "printedName": "Element"
+                }
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "C"
             }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s26AnyBidirectionalCollectionVyAByxGACcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
           ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyBidirectionalCollection",
-              "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "AnyBidirectionalCollection",
-              "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(_:)",
           "declKind": "Constructor",
           "usr": "s:s26AnyBidirectionalCollectionVyAByxGqd__c7ElementQyd__RszSkRd__lufc",
-          "location": "",
           "moduleName": "Swift",
           "genericSig": "<Element, C where Element == C.Element, C : RandomAccessCollection>",
           "declAttributes": [
             "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "AnyBidirectionalCollection",
-              "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Element"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "C"
-            }
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s26AnyBidirectionalCollectionVyAByxGs0a12RandomAccessC0VyxGcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
               "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
               "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s26AnyBidirectionalCollectionVyAByxGs0a12RandomAccessC0VyxGcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s26AnyBidirectionalCollectionVyAByxGSgs0aC0VyxGcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "AnyBidirectionalCollection<Element>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnyBidirectionalCollection",
                   "printedName": "AnyBidirectionalCollection<Element>",
-                  "usr": "s:s26AnyBidirectionalCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s26AnyBidirectionalCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
               "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s26AnyBidirectionalCollectionVyAByxGSgs0aC0VyxGcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s26AnyBidirectionalCollectionV10startIndexs0aE0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -119539,11 +131555,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s26AnyBidirectionalCollectionV10startIndexs0aE0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -119558,21 +131569,24 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s26AnyBidirectionalCollectionV10startIndexs0aE0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s26AnyBidirectionalCollectionV10startIndexs0aE0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s26AnyBidirectionalCollectionV8endIndexs0aE0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -119591,11 +131605,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s26AnyBidirectionalCollectionV8endIndexs0aE0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -119610,22 +131619,111 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s26AnyBidirectionalCollectionV8endIndexs0aE0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s26AnyBidirectionalCollectionV8endIndexs0aE0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Element"
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "AnyBidirectionalCollection<Element>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "AnyIndex",
+                  "printedName": "AnyIndex",
+                  "usr": "s:s8AnyIndexV"
+                }
               ]
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s26AnyBidirectionalCollectionVyxs0A5IndexVcip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "SubSequence",
+              "printedName": "AnyBidirectionalCollection<Element>.SubSequence",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "AnyBidirectionalCollection",
+                  "printedName": "AnyBidirectionalCollection<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:s26AnyBidirectionalCollectionV"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<AnyBidirectionalCollection<Element>.Index>",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "AnyBidirectionalCollection<Element>.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "AnyIndex",
+                      "printedName": "AnyIndex",
+                      "usr": "s:s8AnyIndexV"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s26AnyBidirectionalCollectionVyAByxGSnys0A5IndexVGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV5index5afters0A5IndexVAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -119653,20 +131751,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV5index5afters0A5IndexVAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV9formIndex5afterys0aE0Vz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -119686,20 +131783,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV9formIndex5afterys0aE0Vz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV5index_8offsetBys0A5IndexVAF_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -119733,26 +131829,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV5index_8offsetBys0A5IndexVAF_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV5index_8offsetBy07limitedF0s0A5IndexVSgAG_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "AnyBidirectionalCollection<Element>.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -119767,7 +131861,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -119801,20 +131896,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV5index_8offsetBy07limitedF0s0A5IndexVSgAG_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV9formIndex_8offsetByys0aE0Vz_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -119840,20 +131934,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV9formIndex_8offsetByys0aE0Vz_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV9formIndex_8offsetBy07limitedG0Sbs0aE0Vz_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -119893,20 +131986,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV9formIndex_8offsetBy07limitedG0Sbs0aE0Vz_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV8distance4from2toSis0A5IndexV_AGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -119940,19 +132032,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV8distance4from2toSis0A5IndexV_AGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s26AnyBidirectionalCollectionV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -119964,11 +132056,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s26AnyBidirectionalCollectionV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -119976,74 +132063,74 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s26AnyBidirectionalCollectionV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s26AnyBidirectionalCollectionV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "first",
           "printedName": "first",
-          "declKind": "Var",
-          "usr": "s:s26AnyBidirectionalCollectionV5firstxSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s26AnyBidirectionalCollectionV5firstxSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s26AnyBidirectionalCollectionV5firstxSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s26AnyBidirectionalCollectionV5firstxSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV5index6befores0A5IndexVAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -120071,20 +132158,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV5index6befores0A5IndexVAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:s26AnyBidirectionalCollectionV9formIndex6beforeys0aE0Vz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -120104,112 +132190,106 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s26AnyBidirectionalCollectionV9formIndex6beforeys0aE0Vz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "last",
           "printedName": "last",
-          "declKind": "Var",
-          "usr": "s:s26AnyBidirectionalCollectionV4lastxSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s26AnyBidirectionalCollectionV4lastxSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s26AnyBidirectionalCollectionV4lastxSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s26AnyBidirectionalCollectionV4lastxSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s26AnyBidirectionalCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s26AnyBidirectionalCollectionV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s26AnyBidirectionalCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<Element>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "BidirectionalCollection",
+        "Collection",
+        "Sequence",
+        "_AnyCollectionProtocol"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "AnyRandomAccessCollection",
       "printedName": "AnyRandomAccessCollection",
-      "declKind": "Struct",
-      "usr": "s:s25AnyRandomAccessCollectionV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element>",
-      "conformingProtocols": [
-        "RandomAccessCollection",
-        "BidirectionalCollection",
-        "Collection",
-        "Sequence",
-        "_AnyCollectionProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV12makeIterators0aF0VyxGyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable",
-            "Inline"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -120220,30 +132300,31 @@
                   "kind": "TypeNominal",
                   "name": "AnyIterator",
                   "printedName": "AnyIterator<τ_0_0>",
-                  "usr": "s:s11AnyIteratorV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "τ_0_0"
                     }
-                  ]
+                  ],
+                  "usr": "s:s11AnyIteratorV"
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV12makeIterators0aF0VyxGyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable",
+            "Inline"
           ]
         },
         {
           "kind": "Var",
           "name": "underestimatedCount",
           "printedName": "underestimatedCount",
-          "declKind": "Var",
-          "usr": "s:s25AnyRandomAccessCollectionV19underestimatedCountSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -120255,11 +132336,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s25AnyRandomAccessCollectionV19underestimatedCountSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -120267,45 +132343,42 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25AnyRandomAccessCollectionV19underestimatedCountSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s25AnyRandomAccessCollectionV19underestimatedCountSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "map",
           "printedName": "map(_:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV3mapySayqd__Gqd__xKXEKlF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, T>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[T]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> T",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -120324,45 +132397,44 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV3mapySayqd__Gqd__xKXEKlF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, T>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV6filterySayxGSbxKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -120382,24 +132454,26 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV6filterySayxGSbxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "forEach",
           "printedName": "forEach(_:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV7forEachyyyxKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -120410,9 +132484,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> Void",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -120438,45 +132509,44 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV7forEachyyyxKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "drop",
           "printedName": "drop(while:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV4drop5whileAByxGSbxKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
               "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -120496,35 +132566,39 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV4drop5whileAByxGSbxKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "dropFirst",
           "printedName": "dropFirst(_:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV9dropFirstyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
               "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -120532,33 +132606,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV9dropFirstyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "dropLast",
           "printedName": "dropLast(_:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV8dropLastyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
               "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -120566,43 +132639,37 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV8dropLastyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(while:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV6prefix5whileAByxGSbxKXE_tKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
               "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -120622,35 +132689,39 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV6prefix5whileAByxGSbxKXE_tKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "Function",
           "name": "prefix",
           "printedName": "prefix(_:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV6prefixyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
               "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -120658,33 +132729,32 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV6prefixyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "suffix",
           "printedName": "suffix(_:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV6suffixyAByxGSiF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
               "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             },
             {
               "kind": "TypeNominal",
@@ -120692,43 +132762,40 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV6suffixyAByxGSiF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "split",
           "printedName": "split(maxSplits:omittingEmptySubsequences:whereSeparator:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAByxGGSi_S2bxKXEtKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[AnyRandomAccessCollection<Element>]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnyRandomAccessCollection",
                   "printedName": "AnyRandomAccessCollection<Element>",
-                  "usr": "s:s25AnyRandomAccessCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s25AnyRandomAccessCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeNominal",
@@ -120748,9 +132815,6 @@
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -120770,77 +132834,82 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV5split9maxSplits25omittingEmptySubsequences14whereSeparatorSayAByxGGSi_S2bxKXEtKF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         },
         {
           "kind": "TypeAlias",
           "name": "Indices",
           "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s25AnyRandomAccessCollectionV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DefaultIndices",
               "printedName": "DefaultIndices<AnyRandomAccessCollection<Element>>",
-              "usr": "s:SI",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnyRandomAccessCollection",
                   "printedName": "AnyRandomAccessCollection<Element>",
-                  "usr": "s:s25AnyRandomAccessCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s25AnyRandomAccessCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:SI"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s25AnyRandomAccessCollectionV7Indicesa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s25AnyRandomAccessCollectionV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyIterator",
               "printedName": "AnyIterator<Element>",
-              "usr": "s:s11AnyIteratorV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnyIteratorV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s25AnyRandomAccessCollectionV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "Index",
           "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s25AnyRandomAccessCollectionV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -120848,216 +132917,208 @@
               "printedName": "AnyIndex",
               "usr": "s:s8AnyIndexV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s25AnyRandomAccessCollectionV5Indexa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s25AnyRandomAccessCollectionV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
               "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s25AnyRandomAccessCollectionV11SubSequencea",
+          "moduleName": "Swift",
+          "genericSig": "<Element>"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s25AnyRandomAccessCollectionVyAByxGqd__c7ElementQyd__RszSkRd__lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, C where Element == C.Element, C : RandomAccessCollection>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
               "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "C"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s25AnyRandomAccessCollectionVyAByxGqd__c7ElementQyd__RszSkRd__lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Element, C where Element == C.Element, C : RandomAccessCollection>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s25AnyRandomAccessCollectionVyAByxGACcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
               "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             },
             {
               "kind": "TypeNominal",
               "name": "AnyRandomAccessCollection",
               "printedName": "AnyRandomAccessCollection<Element>",
-              "usr": "s:s25AnyRandomAccessCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s25AnyRandomAccessCollectionV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s25AnyRandomAccessCollectionVyAByxGACcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s25AnyRandomAccessCollectionVyAByxGSgs0aD0VyxGcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "AnyRandomAccessCollection<Element>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnyRandomAccessCollection",
                   "printedName": "AnyRandomAccessCollection<Element>",
-                  "usr": "s:s25AnyRandomAccessCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s25AnyRandomAccessCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
               "printedName": "AnyCollection<Element>",
-              "usr": "s:s13AnyCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s25AnyRandomAccessCollectionVyAByxGSgs0aD0VyxGcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:)",
-          "declKind": "Constructor",
-          "usr": "s:s25AnyRandomAccessCollectionVyAByxGSgs0a13BidirectionalD0VyxGcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "AnyRandomAccessCollection<Element>?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "AnyRandomAccessCollection",
                   "printedName": "AnyRandomAccessCollection<Element>",
-                  "usr": "s:s25AnyRandomAccessCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:s25AnyRandomAccessCollectionV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "AnyBidirectionalCollection",
               "printedName": "AnyBidirectionalCollection<Element>",
-              "usr": "s:s26AnyBidirectionalCollectionV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s26AnyBidirectionalCollectionV"
             }
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s25AnyRandomAccessCollectionVyAByxGSgs0a13BidirectionalD0VyxGcfc",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "startIndex",
           "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s25AnyRandomAccessCollectionV10startIndexs0aF0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -121076,11 +133137,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s25AnyRandomAccessCollectionV10startIndexs0aF0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -121095,21 +133151,24 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25AnyRandomAccessCollectionV10startIndexs0aF0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s25AnyRandomAccessCollectionV10startIndexs0aF0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "endIndex",
           "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s25AnyRandomAccessCollectionV8endIndexs0aF0Vvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -121128,11 +133187,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s25AnyRandomAccessCollectionV8endIndexs0aF0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -121147,22 +133201,111 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25AnyRandomAccessCollectionV8endIndexs0aF0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s25AnyRandomAccessCollectionV8endIndexs0aF0Vvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "Element"
+            },
+            {
+              "kind": "TypeNameAlias",
+              "name": "Index",
+              "printedName": "AnyRandomAccessCollection<Element>.Index",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "AnyIndex",
+                  "printedName": "AnyIndex",
+                  "usr": "s:s8AnyIndexV"
+                }
               ]
             }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s25AnyRandomAccessCollectionVyxs0A5IndexVcip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
+          ]
+        },
+        {
+          "kind": "Subscript",
+          "name": "subscript",
+          "printedName": "subscript(_:)",
+          "children": [
+            {
+              "kind": "TypeNameAlias",
+              "name": "SubSequence",
+              "printedName": "AnyRandomAccessCollection<Element>.SubSequence",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "AnyRandomAccessCollection",
+                  "printedName": "AnyRandomAccessCollection<τ_0_0>",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "GenericTypeParam",
+                      "printedName": "τ_0_0"
+                    }
+                  ],
+                  "usr": "s:s25AnyRandomAccessCollectionV"
+                }
+              ]
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "Range",
+              "printedName": "Range<AnyRandomAccessCollection<Element>.Index>",
+              "children": [
+                {
+                  "kind": "TypeNameAlias",
+                  "name": "Index",
+                  "printedName": "AnyRandomAccessCollection<Element>.Index",
+                  "children": [
+                    {
+                      "kind": "TypeNominal",
+                      "name": "AnyIndex",
+                      "printedName": "AnyIndex",
+                      "usr": "s:s8AnyIndexV"
+                    }
+                  ]
+                }
+              ],
+              "usr": "s:Sn"
+            }
+          ],
+          "declKind": "Subscript",
+          "usr": "s:s25AnyRandomAccessCollectionVyAByxGSnys0A5IndexVGcip",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(after:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV5index5afters0A5IndexVAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -121190,20 +133333,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV5index5afters0A5IndexVAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(after:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV9formIndex5afterys0aF0Vz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -121223,20 +133365,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV9formIndex5afterys0aF0Vz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV5index_8offsetBys0A5IndexVAF_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -121270,26 +133411,24 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV5index_8offsetBys0A5IndexVAF_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV5index_8offsetBy07limitedG0s0A5IndexVSgAG_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "AnyRandomAccessCollection<Element>.Index?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -121304,7 +133443,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNameAlias",
@@ -121338,20 +133478,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV5index_8offsetBy07limitedG0s0A5IndexVSgAG_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV9formIndex_8offsetByys0aF0Vz_SitF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -121377,20 +133516,19 @@
               "printedName": "Int",
               "usr": "s:Si"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV9formIndex_8offsetByys0aF0Vz_SitF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(_:offsetBy:limitedBy:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV9formIndex_8offsetBy07limitedH0Sbs0aF0Vz_SiAGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -121430,20 +133568,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV9formIndex_8offsetBy07limitedH0Sbs0aF0Vz_SiAGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "distance",
           "printedName": "distance(from:to:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV8distance4from2toSis0A5IndexV_AGtF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -121477,19 +133614,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV8distance4from2toSis0A5IndexV_AGtF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "count",
           "printedName": "count",
-          "declKind": "Var",
-          "usr": "s:s25AnyRandomAccessCollectionV5countSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -121501,11 +133638,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s25AnyRandomAccessCollectionV5countSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -121513,74 +133645,74 @@
                   "printedName": "Int",
                   "usr": "s:Si"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25AnyRandomAccessCollectionV5countSivg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s25AnyRandomAccessCollectionV5countSivp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "first",
           "printedName": "first",
-          "declKind": "Var",
-          "usr": "s:s25AnyRandomAccessCollectionV5firstxSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s25AnyRandomAccessCollectionV5firstxSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25AnyRandomAccessCollectionV5firstxSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s25AnyRandomAccessCollectionV5firstxSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "index",
           "printedName": "index(before:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV5index6befores0A5IndexVAF_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -121608,20 +133740,19 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV5index6befores0A5IndexVAF_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Function",
           "name": "formIndex",
           "printedName": "formIndex(before:)",
-          "declKind": "Func",
-          "usr": "s:s25AnyRandomAccessCollectionV9formIndex6beforeys0aF0Vz_tF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -121641,109 +133772,112 @@
                 }
               ]
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s25AnyRandomAccessCollectionV9formIndex6beforeys0aF0Vz_tF",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "Var",
           "name": "last",
           "printedName": "last",
-          "declKind": "Var",
-          "usr": "s:s25AnyRandomAccessCollectionV4lastxSgvp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s25AnyRandomAccessCollectionV4lastxSgvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Element>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "Element"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s25AnyRandomAccessCollectionV4lastxSgvg",
+              "moduleName": "Swift",
+              "genericSig": "<Element>"
             }
+          ],
+          "declKind": "Var",
+          "usr": "s:s25AnyRandomAccessCollectionV4lastxSgvp",
+          "moduleName": "Swift",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s25AnyRandomAccessCollectionV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s25AnyRandomAccessCollectionV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s25AnyRandomAccessCollectionV",
+      "moduleName": "Swift",
+      "genericSig": "<Element>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "RandomAccessCollection",
+        "BidirectionalCollection",
+        "Collection",
+        "Sequence",
+        "_AnyCollectionProtocol"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Mirror",
       "printedName": "Mirror",
-      "declKind": "Struct",
-      "usr": "s:s6MirrorV",
-      "location": "",
-      "moduleName": "Swift",
-      "conformingProtocols": [
-        "CustomStringConvertible",
-        "CustomReflectable"
-      ],
       "children": [
         {
           "kind": "TypeDecl",
           "name": "AncestorRepresentation",
           "printedName": "AncestorRepresentation",
-          "declKind": "Enum",
-          "usr": "s:s6MirrorV22AncestorRepresentationO",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "Var",
               "name": "generated",
               "printedName": "generated",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV22AncestorRepresentationO9generatedyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -121778,16 +133912,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV22AncestorRepresentationO9generatedyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "customized",
               "printedName": "customized",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV22AncestorRepresentationO10customizedyAdByccADmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -121847,16 +133980,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV22AncestorRepresentationO10customizedyAdByccADmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "suppressed",
               "printedName": "suppressed",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV22AncestorRepresentationO10suppressedyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -121891,18 +134023,20 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV22AncestorRepresentationO10suppressedyA2DmF",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Enum",
+          "usr": "s:s6MirrorV22AncestorRepresentationO",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(reflecting:)",
-          "declKind": "Constructor",
-          "usr": "s:s6MirrorV10reflectingAByp_tcfc",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -121915,16 +134049,15 @@
               "name": "ProtocolComposition",
               "printedName": "Any"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6MirrorV10reflectingAByp_tcfc",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "Child",
           "printedName": "Child",
-          "declKind": "TypeAlias",
-          "usr": "s:s6MirrorV5Childa",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -121935,7 +134068,6 @@
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "String?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -121943,7 +134075,8 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -121952,22 +134085,20 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s6MirrorV5Childa",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeAlias",
           "name": "Children",
           "printedName": "Children",
-          "declKind": "TypeAlias",
-          "usr": "s:s6MirrorV8Childrena",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnyCollection",
               "printedName": "AnyCollection<Mirror.Child>",
-              "usr": "s:s13AnyCollectionV",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -121983,7 +134114,6 @@
                           "kind": "TypeNominal",
                           "name": "Optional",
                           "printedName": "Optional<String>",
-                          "usr": "s:Sq",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -121991,7 +134121,8 @@
                               "printedName": "String",
                               "usr": "s:SS"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         },
                         {
                           "kind": "TypeNominal",
@@ -122002,31 +134133,23 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:s13AnyCollectionV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s6MirrorV8Childrena",
+          "moduleName": "Swift"
         },
         {
           "kind": "TypeDecl",
           "name": "DisplayStyle",
           "printedName": "DisplayStyle",
-          "declKind": "Enum",
-          "usr": "s:s6MirrorV12DisplayStyleO",
-          "location": "",
-          "moduleName": "Swift",
-          "conformingProtocols": [
-            "Equatable",
-            "Hashable"
-          ],
           "children": [
             {
               "kind": "Var",
               "name": "struct",
               "printedName": "struct",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV12DisplayStyleO6structyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -122061,16 +134184,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV12DisplayStyleO6structyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "class",
               "printedName": "class",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV12DisplayStyleO5classyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -122105,16 +134227,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV12DisplayStyleO5classyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "enum",
               "printedName": "enum",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV12DisplayStyleO4enumyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -122149,16 +134270,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV12DisplayStyleO4enumyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "tuple",
               "printedName": "tuple",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV12DisplayStyleO5tupleyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -122193,16 +134313,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV12DisplayStyleO5tupleyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "optional",
               "printedName": "optional",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV12DisplayStyleO8optionalyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -122237,16 +134356,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV12DisplayStyleO8optionalyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "collection",
               "printedName": "collection",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV12DisplayStyleO10collectionyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -122281,16 +134399,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV12DisplayStyleO10collectionyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "dictionary",
               "printedName": "dictionary",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV12DisplayStyleO10dictionaryyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -122325,16 +134442,15 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV12DisplayStyleO10dictionaryyA2DmF",
+              "moduleName": "Swift"
             },
             {
               "kind": "Var",
               "name": "set",
               "printedName": "set",
-              "declKind": "EnumElement",
-              "usr": "s:s6MirrorV12DisplayStyleO3setyA2DmF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeFunc",
@@ -122369,16 +134485,48 @@
                     }
                   ]
                 }
+              ],
+              "declKind": "EnumElement",
+              "usr": "s:s6MirrorV12DisplayStyleO3setyA2DmF",
+              "moduleName": "Swift"
+            },
+            {
+              "kind": "Function",
+              "name": "==",
+              "printedName": "==(_:_:)",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Bool",
+                  "printedName": "Bool",
+                  "usr": "s:Sb"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DisplayStyle",
+                  "printedName": "Mirror.DisplayStyle",
+                  "usr": "s:s6MirrorV12DisplayStyleO"
+                },
+                {
+                  "kind": "TypeNominal",
+                  "name": "DisplayStyle",
+                  "printedName": "Mirror.DisplayStyle",
+                  "usr": "s:s6MirrorV12DisplayStyleO"
+                }
+              ],
+              "declKind": "Func",
+              "usr": "s:s6MirrorV12DisplayStyleO2eeoiySbAD_ADtFZ",
+              "moduleName": "Swift",
+              "static": true,
+              "implicit": true,
+              "declAttributes": [
+                "Infix"
               ]
             },
             {
               "kind": "Var",
               "name": "hashValue",
               "printedName": "hashValue",
-              "declKind": "Var",
-              "usr": "s:s6MirrorV12DisplayStyleO9hashValueSivp",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122390,10 +134538,6 @@
                   "kind": "Getter",
                   "name": "_",
                   "printedName": "_()",
-                  "declKind": "Accessor",
-                  "usr": "s:s6MirrorV12DisplayStyleO9hashValueSivg",
-                  "location": "",
-                  "moduleName": "Swift",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -122401,18 +134545,22 @@
                       "printedName": "Int",
                       "usr": "s:Si"
                     }
-                  ]
+                  ],
+                  "declKind": "Accessor",
+                  "usr": "s:s6MirrorV12DisplayStyleO9hashValueSivg",
+                  "moduleName": "Swift",
+                  "implicit": true
                 }
-              ]
+              ],
+              "declKind": "Var",
+              "usr": "s:s6MirrorV12DisplayStyleO9hashValueSivp",
+              "moduleName": "Swift",
+              "implicit": true
             },
             {
               "kind": "Function",
               "name": "hash",
               "printedName": "hash(into:)",
-              "declKind": "Func",
-              "usr": "s:s6MirrorV12DisplayStyleO4hash4intoys6HasherVz_tF",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122425,19 +134573,25 @@
                   "printedName": "Hasher",
                   "usr": "s:s6HasherV"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s6MirrorV12DisplayStyleO4hash4intoys6HasherVz_tF",
+              "moduleName": "Swift",
+              "implicit": true
             }
+          ],
+          "declKind": "Enum",
+          "usr": "s:s6MirrorV12DisplayStyleO",
+          "moduleName": "Swift",
+          "conformingProtocols": [
+            "Equatable",
+            "Hashable"
           ]
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:children:displayStyle:ancestorRepresentation:)",
-          "declKind": "Constructor",
-          "usr": "s:s6MirrorV_8children12displayStyle22ancestorRepresentationABx_q_AB07DisplayD0OSgAB08AncestorF0OtcSlR_SSSg5label_yp5valuet7ElementRt_r0_lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Subject, C where C : Collection, C.Element == Mirror.Child>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -122459,8 +134613,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Mirror.DisplayStyle?",
-              "hasDefaultArg": true,
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122468,7 +134620,9 @@
                   "printedName": "Mirror.DisplayStyle",
                   "usr": "s:s6MirrorV12DisplayStyleO"
                 }
-              ]
+              ],
+              "hasDefaultArg": true,
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -122477,17 +134631,16 @@
               "hasDefaultArg": true,
               "usr": "s:s6MirrorV22AncestorRepresentationO"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6MirrorV_8children12displayStyle22ancestorRepresentationABx_q_AB07DisplayD0OSgAB08AncestorF0OtcSlR_SSSg5label_yp5valuet7ElementRt_r0_lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Subject, C where C : Collection, C.Element == Mirror.Child>"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:unlabeledChildren:displayStyle:ancestorRepresentation:)",
-          "declKind": "Constructor",
-          "usr": "s:s6MirrorV_17unlabeledChildren12displayStyle22ancestorRepresentationABx_q_AB07DisplayE0OSgAB08AncestorG0OtcSlR_r0_lufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Subject, C where C : Collection>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -122509,8 +134662,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Mirror.DisplayStyle?",
-              "hasDefaultArg": true,
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122518,7 +134669,9 @@
                   "printedName": "Mirror.DisplayStyle",
                   "usr": "s:s6MirrorV12DisplayStyleO"
                 }
-              ]
+              ],
+              "hasDefaultArg": true,
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -122527,17 +134680,16 @@
               "hasDefaultArg": true,
               "usr": "s:s6MirrorV22AncestorRepresentationO"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6MirrorV_17unlabeledChildren12displayStyle22ancestorRepresentationABx_q_AB07DisplayE0OSgAB08AncestorG0OtcSlR_r0_lufc",
+          "moduleName": "Swift",
+          "genericSig": "<Subject, C where C : Collection>"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(_:children:displayStyle:ancestorRepresentation:)",
-          "declKind": "Constructor",
-          "usr": "s:s6MirrorV_8children12displayStyle22ancestorRepresentationABx_s17DictionaryLiteralVySSypGAB07DisplayD0OSgAB08AncestorF0Otclufc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Subject>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -122552,9 +134704,8 @@
             },
             {
               "kind": "TypeNominal",
-              "name": "DictionaryLiteral",
-              "printedName": "DictionaryLiteral<String, Any>",
-              "usr": "s:s17DictionaryLiteralV",
+              "name": "KeyValuePairs",
+              "printedName": "KeyValuePairs<String, Any>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122567,14 +134718,13 @@
                   "name": "ProtocolComposition",
                   "printedName": "Any"
                 }
-              ]
+              ],
+              "usr": "s:s13KeyValuePairsV"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Mirror.DisplayStyle?",
-              "hasDefaultArg": true,
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122582,7 +134732,9 @@
                   "printedName": "Mirror.DisplayStyle",
                   "usr": "s:s6MirrorV12DisplayStyleO"
                 }
-              ]
+              ],
+              "hasDefaultArg": true,
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -122591,16 +134743,16 @@
               "hasDefaultArg": true,
               "usr": "s:s6MirrorV22AncestorRepresentationO"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6MirrorV_8children12displayStyle22ancestorRepresentationABx_s13KeyValuePairsVySSypGAB07DisplayD0OSgAB08AncestorF0Otclufc",
+          "moduleName": "Swift",
+          "genericSig": "<Subject>"
         },
         {
           "kind": "Var",
           "name": "subjectType",
           "printedName": "subjectType",
-          "declKind": "Var",
-          "usr": "s:s6MirrorV11subjectTypeypXpvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -122618,10 +134770,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6MirrorV11subjectTypeypXpvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122635,18 +134783,23 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6MirrorV11subjectTypeypXpvg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6MirrorV11subjectTypeypXpvp",
+          "moduleName": "Swift",
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Var",
           "name": "children",
           "printedName": "children",
-          "declKind": "Var",
-          "usr": "s:s6MirrorV8childrens13AnyCollectionVySSSg5label_yp5valuetGvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNameAlias",
@@ -122657,7 +134810,6 @@
                   "kind": "TypeNominal",
                   "name": "AnyCollection",
                   "printedName": "AnyCollection<(label: Optional<String>, value: Any)>",
-                  "usr": "s:s13AnyCollectionV",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -122668,7 +134820,6 @@
                           "kind": "TypeNominal",
                           "name": "Optional",
                           "printedName": "Optional<String>",
-                          "usr": "s:Sq",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -122676,7 +134827,8 @@
                               "printedName": "String",
                               "usr": "s:SS"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sq"
                         },
                         {
                           "kind": "TypeNominal",
@@ -122685,7 +134837,8 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:s13AnyCollectionV"
                 }
               ]
             },
@@ -122693,10 +134846,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6MirrorV8childrens13AnyCollectionVySSSg5label_yp5valuetGvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNameAlias",
@@ -122707,7 +134856,6 @@
                       "kind": "TypeNominal",
                       "name": "AnyCollection",
                       "printedName": "AnyCollection<(label: Optional<String>, value: Any)>",
-                      "usr": "s:s13AnyCollectionV",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -122718,7 +134866,6 @@
                               "kind": "TypeNominal",
                               "name": "Optional",
                               "printedName": "Optional<String>",
-                              "usr": "s:Sq",
                               "children": [
                                 {
                                   "kind": "TypeNominal",
@@ -122726,7 +134873,8 @@
                                   "printedName": "String",
                                   "usr": "s:SS"
                                 }
-                              ]
+                              ],
+                              "usr": "s:Sq"
                             },
                             {
                               "kind": "TypeNominal",
@@ -122735,28 +134883,33 @@
                             }
                           ]
                         }
-                      ]
+                      ],
+                      "usr": "s:s13AnyCollectionV"
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6MirrorV8childrens13AnyCollectionVySSSg5label_yp5valuetGvg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6MirrorV8childrens13AnyCollectionVySSSg5label_yp5valuetGvp",
+          "moduleName": "Swift",
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Var",
           "name": "displayStyle",
           "printedName": "displayStyle",
-          "declKind": "Var",
-          "usr": "s:s6MirrorV12displayStyleAB07DisplayC0OSgvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Mirror.DisplayStyle?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122764,22 +134917,18 @@
                   "printedName": "Mirror.DisplayStyle",
                   "usr": "s:s6MirrorV12DisplayStyleO"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6MirrorV12displayStyleAB07DisplayC0OSgvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Mirror.DisplayStyle?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -122787,26 +134936,31 @@
                       "printedName": "Mirror.DisplayStyle",
                       "usr": "s:s6MirrorV12DisplayStyleO"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6MirrorV12displayStyleAB07DisplayC0OSgvg",
+              "moduleName": "Swift",
+              "implicit": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6MirrorV12displayStyleAB07DisplayC0OSgvp",
+          "moduleName": "Swift",
+          "isLet": true,
+          "hasStorage": true
         },
         {
           "kind": "Var",
           "name": "superclassMirror",
           "printedName": "superclassMirror",
-          "declKind": "Var",
-          "usr": "s:s6MirrorV010superclassA0ABSgvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Mirror?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122814,22 +134968,18 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6MirrorV010superclassA0ABSgvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Mirror?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -122837,20 +134987,23 @@
                       "printedName": "Mirror",
                       "usr": "s:s6MirrorV"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6MirrorV010superclassA0ABSgvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6MirrorV010superclassA0ABSgvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(internalReflecting:subjectType:customAncestor:)",
-          "declKind": "Constructor",
-          "usr": "s:s6MirrorV18internalReflecting11subjectType14customAncestorAByp_ypXpSgABSgtcfc",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -122867,8 +135020,6 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Any.Type?",
-              "hasDefaultArg": true,
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122882,14 +135033,14 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "hasDefaultArg": true,
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Mirror?",
-              "hasDefaultArg": true,
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122897,31 +135048,33 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "hasDefaultArg": true,
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Constructor",
+          "usr": "s:s6MirrorV18internalReflecting11subjectType14customAncestorAByp_ypXpSgABSgtcfc",
+          "moduleName": "Swift",
+          "isInternal": true
         },
         {
           "kind": "Function",
           "name": "descendant",
           "printedName": "descendant(_:_:)",
-          "declKind": "Func",
-          "usr": "s:s6MirrorV10descendantyypSgs0A4Path_p_sAE_pdtF",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Any?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ProtocolComposition",
                   "printedName": "Any"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -122933,7 +135086,6 @@
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[MirrorPath]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122941,18 +135093,18 @@
                   "printedName": "MirrorPath",
                   "usr": "s:s10MirrorPathP"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s6MirrorV10descendantyypSgs0A4Path_p_sAE_pdtF",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "description",
           "printedName": "description",
-          "declKind": "Var",
-          "usr": "s:s6MirrorV11descriptionSSvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -122964,10 +135116,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6MirrorV11descriptionSSvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -122975,18 +135123,20 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6MirrorV11descriptionSSvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6MirrorV11descriptionSSvp",
+          "moduleName": "Swift"
         },
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s6MirrorV06customA0ABvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -122998,10 +135148,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s6MirrorV06customA0ABvg",
-              "location": "",
-              "moduleName": "Swift",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -123009,29 +135155,34 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s6MirrorV06customA0ABvg",
+              "moduleName": "Swift"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s6MirrorV06customA0ABvp",
+          "moduleName": "Swift"
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s6MirrorV",
+      "moduleName": "Swift",
+      "conformingProtocols": [
+        "CustomStringConvertible",
+        "CustomReflectable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "CustomReflectable",
       "printedName": "CustomReflectable",
-      "declKind": "Protocol",
-      "usr": "s:s17CustomReflectableP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "customMirror",
           "printedName": "customMirror",
-          "declKind": "Var",
-          "usr": "s:s17CustomReflectableP12customMirrors0D0Vvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -123043,11 +135194,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17CustomReflectableP12customMirrors0D0Vvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CustomReflectable>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -123055,11 +135201,22 @@
                   "printedName": "Mirror",
                   "usr": "s:s6MirrorV"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s17CustomReflectableP12customMirrors0D0Vvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : CustomReflectable>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s17CustomReflectableP12customMirrors0D0Vvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s17CustomReflectableP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
@@ -123067,7 +135224,6 @@
       "printedName": "CustomLeafReflectable",
       "declKind": "Protocol",
       "usr": "s:s21CustomLeafReflectableP",
-      "location": "",
       "moduleName": "Swift",
       "genericSig": "<Self : CustomReflectable>",
       "conformingProtocols": [
@@ -123080,362 +135236,17 @@
       "printedName": "MirrorPath",
       "declKind": "Protocol",
       "usr": "s:s10MirrorPathP",
-      "location": "",
       "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
-      "name": "DictionaryLiteral",
-      "printedName": "DictionaryLiteral",
-      "declKind": "Struct",
-      "usr": "s:s17DictionaryLiteralV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Key, Value>",
-      "conformingProtocols": [
-        "ExpressibleByDictionaryLiteral",
-        "RandomAccessCollection",
-        "BidirectionalCollection",
-        "Collection",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
-      "children": [
-        {
-          "kind": "Constructor",
-          "name": "init",
-          "printedName": "init(dictionaryLiteral:)",
-          "declKind": "Constructor",
-          "usr": "s:s17DictionaryLiteralV010dictionaryB0AByxq_Gx_q_td_tcfc",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "DictionaryLiteral",
-              "printedName": "DictionaryLiteral<Key, Value>",
-              "usr": "s:s17DictionaryLiteralV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Key"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
-                }
-              ]
-            },
-            {
-              "kind": "TypeNominal",
-              "name": "Array",
-              "printedName": "[(Key, Value)]",
-              "usr": "s:Sa",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Tuple",
-                  "printedName": "(Key, Value)",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Key",
-          "printedName": "Key",
-          "declKind": "TypeAlias",
-          "usr": "s:s17DictionaryLiteralV3Keya",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Key"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Value",
-          "printedName": "Value",
-          "declKind": "TypeAlias",
-          "usr": "s:s17DictionaryLiteralV5Valuea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "GenericTypeParam",
-              "printedName": "Value"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Indices",
-          "printedName": "Indices",
-          "declKind": "TypeAlias",
-          "usr": "s:s17DictionaryLiteralV7Indicesa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Range",
-              "printedName": "Range<Int>",
-              "usr": "s:Sn",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "startIndex",
-          "printedName": "startIndex",
-          "declKind": "Var",
-          "usr": "s:s17DictionaryLiteralV10startIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17DictionaryLiteralV10startIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "Var",
-          "name": "endIndex",
-          "printedName": "endIndex",
-          "declKind": "Var",
-          "usr": "s:s17DictionaryLiteralV8endIndexSivp",
-          "location": "",
-          "moduleName": "Swift",
-          "declAttributes": [
-            "Inlinable"
-          ],
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            },
-            {
-              "kind": "Getter",
-              "name": "_",
-              "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s17DictionaryLiteralV8endIndexSivg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Key, Value>",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "Int",
-                  "printedName": "Int",
-                  "usr": "s:Si"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Element",
-          "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s17DictionaryLiteralV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Tuple",
-              "printedName": "(key: Key, value: Value)",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Key"
-                },
-                {
-                  "kind": "TypeNominal",
-                  "name": "GenericTypeParam",
-                  "printedName": "Value"
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Index",
-          "printedName": "Index",
-          "declKind": "TypeAlias",
-          "usr": "s:s17DictionaryLiteralV5Indexa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Int",
-              "printedName": "Int",
-              "usr": "s:Si"
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "SubSequence",
-          "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s17DictionaryLiteralV11SubSequencea",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "Slice",
-              "printedName": "Slice<DictionaryLiteral<Key, Value>>",
-              "usr": "s:s5SliceV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DictionaryLiteral",
-                  "printedName": "DictionaryLiteral<Key, Value>",
-                  "usr": "s:s17DictionaryLiteralV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        },
-        {
-          "kind": "TypeAlias",
-          "name": "Iterator",
-          "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s17DictionaryLiteralV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Key, Value>",
-          "children": [
-            {
-              "kind": "TypeNominal",
-              "name": "IndexingIterator",
-              "printedName": "IndexingIterator<DictionaryLiteral<Key, Value>>",
-              "usr": "s:s16IndexingIteratorV",
-              "children": [
-                {
-                  "kind": "TypeNominal",
-                  "name": "DictionaryLiteral",
-                  "printedName": "DictionaryLiteral<Key, Value>",
-                  "usr": "s:s17DictionaryLiteralV",
-                  "children": [
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Key"
-                    },
-                    {
-                      "kind": "TypeNominal",
-                      "name": "GenericTypeParam",
-                      "printedName": "Value"
-                    }
-                  ]
-                }
-              ]
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "kind": "TypeDecl",
       "name": "CustomPlaygroundDisplayConvertible",
       "printedName": "CustomPlaygroundDisplayConvertible",
-      "declKind": "Protocol",
-      "usr": "s:s34CustomPlaygroundDisplayConvertibleP",
-      "location": "",
-      "moduleName": "Swift",
       "children": [
         {
           "kind": "Var",
           "name": "playgroundDescription",
           "printedName": "playgroundDescription",
-          "declKind": "Var",
-          "usr": "s:s34CustomPlaygroundDisplayConvertibleP21playgroundDescriptionypvp",
-          "location": "",
-          "moduleName": "Swift",
           "children": [
             {
               "kind": "TypeNominal",
@@ -123446,47 +135257,38 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s34CustomPlaygroundDisplayConvertibleP21playgroundDescriptionypvg",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Self where Self : CustomPlaygroundDisplayConvertible>",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "ProtocolComposition",
                   "printedName": "Any"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s34CustomPlaygroundDisplayConvertibleP21playgroundDescriptionypvg",
+              "moduleName": "Swift",
+              "genericSig": "<Self where Self : CustomPlaygroundDisplayConvertible>"
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s34CustomPlaygroundDisplayConvertibleP21playgroundDescriptionypvp",
+          "moduleName": "Swift",
+          "protocolReq": true
         }
-      ]
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s34CustomPlaygroundDisplayConvertibleP",
+      "moduleName": "Swift"
     },
     {
       "kind": "TypeDecl",
       "name": "CommandLine",
       "printedName": "CommandLine",
-      "declKind": "Enum",
-      "usr": "s:s11CommandLineO",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Frozen"
-      ],
       "children": [
         {
           "kind": "Var",
           "name": "argc",
           "printedName": "argc",
-          "declKind": "Var",
-          "usr": "s:s11CommandLineO4argcs5Int32VvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -123498,11 +135300,6 @@
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11CommandLineO4argcs5Int32VvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -123510,40 +135307,37 @@
                   "printedName": "Int32",
                   "usr": "s:s5Int32V"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11CommandLineO4argcs5Int32VvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s11CommandLineO4argcs5Int32VvpZ",
+          "moduleName": "Swift",
+          "static": true
         },
         {
           "kind": "Var",
           "name": "unsafeArgv",
           "printedName": "unsafeArgv",
-          "declKind": "Var",
-          "usr": "s:s11CommandLineO10unsafeArgvSpySpys4Int8VGSgGvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnsafeMutablePointer",
               "printedName": "UnsafeMutablePointer<UnsafeMutablePointer<Int8>?>",
-              "usr": "s:Sp",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "UnsafeMutablePointer<Int8>?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "UnsafeMutablePointer",
                       "printedName": "UnsafeMutablePointer<Int8>",
-                      "usr": "s:Sp",
                       "children": [
                         {
                           "kind": "TypeNominal",
@@ -123551,39 +135345,34 @@
                           "printedName": "Int8",
                           "usr": "s:s4Int8V"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sp"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "usr": "s:Sp"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11CommandLineO10unsafeArgvSpySpys4Int8VGSgGvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "UnsafeMutablePointer",
                   "printedName": "UnsafeMutablePointer<UnsafeMutablePointer<Int8>?>",
-                  "usr": "s:Sp",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "Optional",
                       "printedName": "UnsafeMutablePointer<Int8>?",
-                      "usr": "s:Sq",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "UnsafeMutablePointer",
                           "printedName": "UnsafeMutablePointer<Int8>",
-                          "usr": "s:Sp",
                           "children": [
                             {
                               "kind": "TypeNominal",
@@ -123591,34 +135380,36 @@
                               "printedName": "Int8",
                               "usr": "s:s4Int8V"
                             }
-                          ]
+                          ],
+                          "usr": "s:Sp"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sp"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11CommandLineO10unsafeArgvSpySpys4Int8VGSgGvgZ",
+              "moduleName": "Swift",
+              "static": true
             }
-          ]
+          ],
+          "declKind": "Var",
+          "usr": "s:s11CommandLineO10unsafeArgvSpySpys4Int8VGSgGvpZ",
+          "moduleName": "Swift",
+          "static": true
         },
         {
           "kind": "Var",
           "name": "arguments",
           "printedName": "arguments",
-          "declKind": "Var",
-          "usr": "s:s11CommandLineO9argumentsSaySSGvpZ",
-          "location": "",
-          "moduleName": "Swift",
-          "static": true,
-          "declAttributes": [
-            "HasInitialValue"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[String]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -123626,23 +135417,18 @@
                   "printedName": "String",
                   "usr": "s:SS"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "Getter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11CommandLineO9argumentsSaySSGvgZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[String]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -123650,19 +135436,20 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11CommandLineO9argumentsSaySSGvgZ",
+              "moduleName": "Swift",
+              "static": true,
+              "implicit": true
             },
             {
               "kind": "Setter",
               "name": "_",
               "printedName": "_()",
-              "declKind": "Accessor",
-              "usr": "s:s11CommandLineO9argumentsSaySSGvsZ",
-              "location": "",
-              "moduleName": "Swift",
-              "static": true,
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -123673,7 +135460,6 @@
                   "kind": "TypeNominal",
                   "name": "Array",
                   "printedName": "[String]",
-                  "usr": "s:Sa",
                   "children": [
                     {
                       "kind": "TypeNominal",
@@ -123681,26 +135467,2432 @@
                       "printedName": "String",
                       "usr": "s:SS"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sa"
                 }
-              ]
+              ],
+              "declKind": "Accessor",
+              "usr": "s:s11CommandLineO9argumentsSaySSGvsZ",
+              "moduleName": "Swift",
+              "static": true,
+              "implicit": true
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:s11CommandLineO9argumentsSaySSGvpZ",
+          "moduleName": "Swift",
+          "static": true,
+          "declAttributes": [
+            "HasInitialValue"
+          ],
+          "hasStorage": true
+        }
+      ],
+      "declKind": "Enum",
+      "usr": "s:s11CommandLineO",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Frozen"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "==",
+      "printedName": "==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2eeoiySbyt_yttF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbyt_yttF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<",
+      "printedName": "<(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1loiySbyt_yttF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<=",
+      "printedName": "<=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2leoiySbyt_yttF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">",
+      "printedName": ">(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1goiySbyt_yttF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">=",
+      "printedName": ">=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Void",
+          "printedName": "()"
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2geoiySbyt_yttF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "==",
+      "printedName": "==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
             }
           ]
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2eeoiySbx_q_t_x_q_ttSQRzSQR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B where A : Equatable, B : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbx_q_t_x_q_ttSQRzSQR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B where A : Equatable, B : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<",
+      "printedName": "<(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1loiySbx_q_t_x_q_ttSLRzSLR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B where A : Comparable, B : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<=",
+      "printedName": "<=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2leoiySbx_q_t_x_q_ttSLRzSLR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B where A : Comparable, B : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">",
+      "printedName": ">(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1goiySbx_q_t_x_q_ttSLRzSLR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B where A : Comparable, B : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">=",
+      "printedName": ">=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2geoiySbx_q_t_x_q_ttSLRzSLR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B where A : Comparable, B : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "==",
+      "printedName": "==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2eeoiySbx_q_q0_t_x_q_q0_ttSQRzSQR_SQR0_r1_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C where A : Equatable, B : Equatable, C : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbx_q_q0_t_x_q_q0_ttSQRzSQR_SQR0_r1_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C where A : Equatable, B : Equatable, C : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<",
+      "printedName": "<(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1loiySbx_q_q0_t_x_q_q0_ttSLRzSLR_SLR0_r1_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C where A : Comparable, B : Comparable, C : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<=",
+      "printedName": "<=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2leoiySbx_q_q0_t_x_q_q0_ttSLRzSLR_SLR0_r1_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C where A : Comparable, B : Comparable, C : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">",
+      "printedName": ">(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1goiySbx_q_q0_t_x_q_q0_ttSLRzSLR_SLR0_r1_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C where A : Comparable, B : Comparable, C : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">=",
+      "printedName": ">=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2geoiySbx_q_q0_t_x_q_q0_ttSLRzSLR_SLR0_r1_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C where A : Comparable, B : Comparable, C : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "==",
+      "printedName": "==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2eeoiySbx_q_q0_q1_t_x_q_q0_q1_ttSQRzSQR_SQR0_SQR1_r2_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D where A : Equatable, B : Equatable, C : Equatable, D : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbx_q_q0_q1_t_x_q_q0_q1_ttSQRzSQR_SQR0_SQR1_r2_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D where A : Equatable, B : Equatable, C : Equatable, D : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<",
+      "printedName": "<(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1loiySbx_q_q0_q1_t_x_q_q0_q1_ttSLRzSLR_SLR0_SLR1_r2_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D where A : Comparable, B : Comparable, C : Comparable, D : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<=",
+      "printedName": "<=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2leoiySbx_q_q0_q1_t_x_q_q0_q1_ttSLRzSLR_SLR0_SLR1_r2_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D where A : Comparable, B : Comparable, C : Comparable, D : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">",
+      "printedName": ">(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1goiySbx_q_q0_q1_t_x_q_q0_q1_ttSLRzSLR_SLR0_SLR1_r2_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D where A : Comparable, B : Comparable, C : Comparable, D : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">=",
+      "printedName": ">=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2geoiySbx_q_q0_q1_t_x_q_q0_q1_ttSLRzSLR_SLR0_SLR1_r2_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D where A : Comparable, B : Comparable, C : Comparable, D : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "==",
+      "printedName": "==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2eeoiySbx_q_q0_q1_q2_t_x_q_q0_q1_q2_ttSQRzSQR_SQR0_SQR1_SQR2_r3_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D, E where A : Equatable, B : Equatable, C : Equatable, D : Equatable, E : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbx_q_q0_q1_q2_t_x_q_q0_q1_q2_ttSQRzSQR_SQR0_SQR1_SQR2_r3_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D, E where A : Equatable, B : Equatable, C : Equatable, D : Equatable, E : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<",
+      "printedName": "<(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1loiySbx_q_q0_q1_q2_t_x_q_q0_q1_q2_ttSLRzSLR_SLR0_SLR1_SLR2_r3_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D, E where A : Comparable, B : Comparable, C : Comparable, D : Comparable, E : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<=",
+      "printedName": "<=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2leoiySbx_q_q0_q1_q2_t_x_q_q0_q1_q2_ttSLRzSLR_SLR0_SLR1_SLR2_r3_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D, E where A : Comparable, B : Comparable, C : Comparable, D : Comparable, E : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">",
+      "printedName": ">(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1goiySbx_q_q0_q1_q2_t_x_q_q0_q1_q2_ttSLRzSLR_SLR0_SLR1_SLR2_r3_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D, E where A : Comparable, B : Comparable, C : Comparable, D : Comparable, E : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">=",
+      "printedName": ">=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2geoiySbx_q_q0_q1_q2_t_x_q_q0_q1_q2_ttSLRzSLR_SLR0_SLR1_SLR2_r3_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D, E where A : Comparable, B : Comparable, C : Comparable, D : Comparable, E : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "==",
+      "printedName": "==(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E, F)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "F"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E, F)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "F"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2eeoiySbx_q_q0_q1_q2_q3_t_x_q_q0_q1_q2_q3_ttSQRzSQR_SQR0_SQR1_SQR2_SQR3_r4_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D, E, F where A : Equatable, B : Equatable, C : Equatable, D : Equatable, E : Equatable, F : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "!=",
+      "printedName": "!=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E, F)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "F"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E, F)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "F"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2neoiySbx_q_q0_q1_q2_q3_t_x_q_q0_q1_q2_q3_ttSQRzSQR_SQR0_SQR1_SQR2_SQR3_r4_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D, E, F where A : Equatable, B : Equatable, C : Equatable, D : Equatable, E : Equatable, F : Equatable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<",
+      "printedName": "<(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E, F)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "F"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E, F)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "F"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1loiySbx_q_q0_q1_q2_q3_t_x_q_q0_q1_q2_q3_ttSLRzSLR_SLR0_SLR1_SLR2_SLR3_r4_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D, E, F where A : Comparable, B : Comparable, C : Comparable, D : Comparable, E : Comparable, F : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": "<=",
+      "printedName": "<=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E, F)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "F"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E, F)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "F"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2leoiySbx_q_q0_q1_q2_q3_t_x_q_q0_q1_q2_q3_ttSLRzSLR_SLR0_SLR1_SLR2_SLR3_r4_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D, E, F where A : Comparable, B : Comparable, C : Comparable, D : Comparable, E : Comparable, F : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">",
+      "printedName": ">(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E, F)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "F"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E, F)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "F"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s1goiySbx_q_q0_q1_q2_q3_t_x_q_q0_q1_q2_q3_ttSLRzSLR_SLR0_SLR1_SLR2_SLR3_r4_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D, E, F where A : Comparable, B : Comparable, C : Comparable, D : Comparable, E : Comparable, F : Comparable>",
+      "declAttributes": [
+        "Inlinable"
+      ]
+    },
+    {
+      "kind": "Function",
+      "name": ">=",
+      "printedName": ">=(_:_:)",
+      "children": [
+        {
+          "kind": "TypeNominal",
+          "name": "Bool",
+          "printedName": "Bool",
+          "usr": "s:Sb"
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E, F)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "F"
+            }
+          ]
+        },
+        {
+          "kind": "TypeNominal",
+          "name": "Tuple",
+          "printedName": "(A, B, C, D, E, F)",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "A"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "B"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "C"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "D"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "E"
+            },
+            {
+              "kind": "TypeNominal",
+              "name": "GenericTypeParam",
+              "printedName": "F"
+            }
+          ]
+        }
+      ],
+      "declKind": "Func",
+      "usr": "s:s2geoiySbx_q_q0_q1_q2_q3_t_x_q_q0_q1_q2_q3_ttSLRzSLR_SLR0_SLR1_SLR2_SLR3_r4_lF",
+      "moduleName": "Swift",
+      "genericSig": "<A, B, C, D, E, F where A : Comparable, B : Comparable, C : Comparable, D : Comparable, E : Comparable, F : Comparable>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "sequence",
       "printedName": "sequence(first:next:)",
-      "declKind": "Func",
-      "usr": "s:s8sequence5first4nexts14UnfoldSequenceVyxxSg_SbtGx_AFxctlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNameAlias",
@@ -123711,7 +137903,6 @@
               "kind": "TypeNominal",
               "name": "UnfoldSequence",
               "printedName": "UnfoldSequence<τ_0_0, (Optional<τ_0_0>, Bool)>",
-              "usr": "s:s14UnfoldSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -123727,14 +137918,14 @@
                       "kind": "TypeNominal",
                       "name": "Optional",
                       "printedName": "Optional<τ_0_0>",
-                      "usr": "s:Sq",
                       "children": [
                         {
                           "kind": "TypeNominal",
                           "name": "GenericTypeParam",
                           "printedName": "τ_0_0"
                         }
-                      ]
+                      ],
+                      "usr": "s:Sq"
                     },
                     {
                       "kind": "TypeNominal",
@@ -123744,7 +137935,8 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:s14UnfoldSequenceV"
             }
           ]
         },
@@ -123762,14 +137954,14 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "T?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -123785,26 +137977,24 @@
             }
           ]
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s8sequence5first4nexts14UnfoldSequenceVyxxSg_SbtGx_AFxctlF",
+      "moduleName": "Swift",
+      "genericSig": "<T>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "sequence",
       "printedName": "sequence(state:next:)",
-      "declKind": "Func",
-      "usr": "s:s8sequence5state4nexts14UnfoldSequenceVyxq_Gq__xSgq_zctr0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T, State>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "UnfoldSequence",
           "printedName": "UnfoldSequence<T, State>",
-          "usr": "s:s14UnfoldSequenceV",
           "children": [
             {
               "kind": "TypeNominal",
@@ -123816,7 +138006,8 @@
               "name": "GenericTypeParam",
               "printedName": "State"
             }
-          ]
+          ],
+          "usr": "s:s14UnfoldSequenceV"
         },
         {
           "kind": "TypeNominal",
@@ -123832,14 +138023,14 @@
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "T?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "T"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             },
             {
               "kind": "TypeNominal",
@@ -123855,23 +138046,24 @@
             }
           ]
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s8sequence5state4nexts14UnfoldSequenceVyxq_Gq__xSgq_zctr0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<T, State>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeAlias",
       "name": "UnfoldFirstSequence",
       "printedName": "UnfoldFirstSequence",
-      "declKind": "TypeAlias",
-      "usr": "s:s19UnfoldFirstSequencea",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<T>",
       "children": [
         {
           "kind": "TypeNominal",
           "name": "UnfoldSequence",
           "printedName": "UnfoldSequence<T, (T?, Bool)>",
-          "usr": "s:s14UnfoldSequenceV",
           "children": [
             {
               "kind": "TypeNominal",
@@ -123887,14 +138079,14 @@
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "T?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNominal",
                       "name": "GenericTypeParam",
                       "printedName": "T"
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 },
                 {
                   "kind": "TypeNominal",
@@ -123904,88 +138096,74 @@
                 }
               ]
             }
-          ]
+          ],
+          "usr": "s:s14UnfoldSequenceV"
         }
-      ]
+      ],
+      "declKind": "TypeAlias",
+      "usr": "s:s19UnfoldFirstSequencea",
+      "moduleName": "Swift",
+      "genericSig": "<T>"
     },
     {
       "kind": "TypeDecl",
       "name": "UnfoldSequence",
       "printedName": "UnfoldSequence",
-      "declKind": "Struct",
-      "usr": "s:s14UnfoldSequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Element, State>",
-      "conformingProtocols": [
-        "Sequence",
-        "IteratorProtocol"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "Function",
           "name": "next",
           "printedName": "next()",
-          "declKind": "Func",
-          "usr": "s:s14UnfoldSequenceV4nextxSgyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, State>",
-          "mutating": true,
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Optional",
               "printedName": "Element?",
-              "usr": "s:Sq",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:Sq"
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s14UnfoldSequenceV4nextxSgyF",
+          "moduleName": "Swift",
+          "genericSig": "<Element, State>",
+          "declAttributes": [
+            "Inlinable"
+          ],
+          "mutating": true
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s14UnfoldSequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, State>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "GenericTypeParam",
               "printedName": "Element"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s14UnfoldSequenceV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Element, State>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "TypeAlias",
-          "usr": "s:s14UnfoldSequenceV8Iteratora",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, State>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "UnfoldSequence",
               "printedName": "UnfoldSequence<Element, State>",
-              "usr": "s:s14UnfoldSequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -123997,35 +138175,52 @@
                   "name": "GenericTypeParam",
                   "printedName": "State"
                 }
-              ]
+              ],
+              "usr": "s:s14UnfoldSequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s14UnfoldSequenceV8Iteratora",
+          "moduleName": "Swift",
+          "genericSig": "<Element, State>",
+          "implicit": true
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s14UnfoldSequenceV03SubB0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Element, State>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<Element>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "GenericTypeParam",
                   "printedName": "Element"
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s14UnfoldSequenceV03SubB0a",
+          "moduleName": "Swift",
+          "genericSig": "<Element, State>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s14UnfoldSequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<Element, State>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "IteratorProtocol"
       ]
     },
     {
@@ -124034,21 +138229,12 @@
       "printedName": "CVarArg",
       "declKind": "Protocol",
       "usr": "s:s7CVarArgP",
-      "location": "",
       "moduleName": "Swift"
     },
     {
       "kind": "Function",
       "name": "withVaList",
       "printedName": "withVaList(_:_:)",
-      "declKind": "Func",
-      "usr": "s:s10withVaListyxSays7CVarArg_pG_xs03CVaC7PointerVXEtlF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<R>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -124059,7 +138245,6 @@
           "kind": "TypeNominal",
           "name": "Array",
           "printedName": "[CVarArg]",
-          "usr": "s:Sa",
           "children": [
             {
               "kind": "TypeNominal",
@@ -124067,15 +138252,13 @@
               "printedName": "CVarArg",
               "usr": "s:s7CVarArgP"
             }
-          ]
+          ],
+          "usr": "s:Sa"
         },
         {
           "kind": "TypeFunc",
           "name": "Function",
           "printedName": "(CVaListPointer) -> R",
-          "typeAttributes": [
-            "noescape"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -124086,7 +138269,6 @@
               "kind": "TypeNominal",
               "name": "Paren",
               "printedName": "(CVaListPointer)",
-              "usr": "s:s14CVaListPointerV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -124094,23 +138276,27 @@
                   "printedName": "CVaListPointer",
                   "usr": "s:s14CVaListPointerV"
                 }
-              ]
+              ],
+              "usr": "s:s14CVaListPointerV"
             }
+          ],
+          "typeAttributes": [
+            "noescape"
           ]
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s10withVaListyxSays7CVarArg_pG_xs03CVaC7PointerVXEtlF",
+      "moduleName": "Swift",
+      "genericSig": "<R>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "getVaList",
       "printedName": "getVaList(_:)",
-      "declKind": "Func",
-      "usr": "s:s9getVaListys03CVaC7PointerVSays7CVarArg_pGF",
-      "location": "",
-      "moduleName": "Swift",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
@@ -124122,7 +138308,6 @@
           "kind": "TypeNominal",
           "name": "Array",
           "printedName": "[CVarArg]",
-          "usr": "s:Sa",
           "children": [
             {
               "kind": "TypeNominal",
@@ -124130,28 +138315,26 @@
               "printedName": "CVarArg",
               "usr": "s:s7CVarArgP"
             }
-          ]
+          ],
+          "usr": "s:Sa"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s9getVaListys03CVaC7PointerVSays7CVarArg_pGF",
+      "moduleName": "Swift",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "Function",
       "name": "zip",
       "printedName": "zip(_:_:)",
-      "declKind": "Func",
-      "usr": "s:s3zipys12Zip2SequenceVyxq_Gx_q_tSTRzSTR_r0_lF",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-      "declAttributes": [
-        "Inlinable"
-      ],
       "children": [
         {
           "kind": "TypeNominal",
           "name": "Zip2Sequence",
           "printedName": "Zip2Sequence<Sequence1, Sequence2>",
-          "usr": "s:s12Zip2SequenceV",
           "children": [
             {
               "kind": "TypeNominal",
@@ -124163,7 +138346,8 @@
               "name": "GenericTypeParam",
               "printedName": "Sequence2"
             }
-          ]
+          ],
+          "usr": "s:s12Zip2SequenceV"
         },
         {
           "kind": "TypeNominal",
@@ -124175,52 +138359,29 @@
           "name": "GenericTypeParam",
           "printedName": "Sequence2"
         }
+      ],
+      "declKind": "Func",
+      "usr": "s:s3zipys12Zip2SequenceVyxq_Gx_q_tSTRzSTR_r0_lF",
+      "moduleName": "Swift",
+      "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
+      "declAttributes": [
+        "Inlinable"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "Zip2Sequence",
       "printedName": "Zip2Sequence",
-      "declKind": "Struct",
-      "usr": "s:s12Zip2SequenceV",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-      "conformingProtocols": [
-        "Sequence"
-      ],
-      "declAttributes": [
-        "FixedLayout"
-      ],
       "children": [
         {
           "kind": "TypeDecl",
           "name": "Iterator",
           "printedName": "Iterator",
-          "declKind": "Struct",
-          "usr": "s:s12Zip2SequenceV8IteratorV",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-          "conformingProtocols": [
-            "IteratorProtocol"
-          ],
-          "declAttributes": [
-            "FixedLayout"
-          ],
           "children": [
             {
               "kind": "Constructor",
               "name": "init",
               "printedName": "init(_:_:)",
-              "declKind": "Constructor",
-              "usr": "s:s12Zip2SequenceV8IteratorVyADyxq__GACQz_ACQy_tcfc",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -124238,17 +138399,20 @@
                   "name": "DependentMember",
                   "printedName": "Sequence2.Iterator"
                 }
+              ],
+              "declKind": "Constructor",
+              "usr": "s:s12Zip2SequenceV8IteratorVyADyxq__GACQz_ACQy_tcfc",
+              "moduleName": "Swift",
+              "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
+              "isInternal": true,
+              "declAttributes": [
+                "Inlinable"
               ]
             },
             {
               "kind": "TypeAlias",
               "name": "Element",
               "printedName": "Element",
-              "declKind": "TypeAlias",
-              "usr": "s:s12Zip2SequenceV8IteratorV7Elementa",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -124267,27 +138431,21 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "declKind": "TypeAlias",
+              "usr": "s:s12Zip2SequenceV8IteratorV7Elementa",
+              "moduleName": "Swift",
+              "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>"
             },
             {
               "kind": "Function",
               "name": "next",
               "printedName": "next()",
-              "declKind": "Func",
-              "usr": "s:s12Zip2SequenceV8IteratorV4next7ElementQz_AFQy_tSgyF",
-              "location": "",
-              "moduleName": "Swift",
-              "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-              "mutating": true,
-              "declAttributes": [
-                "Inlinable"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "Optional",
                   "printedName": "Zip2Sequence<Sequence1, Sequence2>.Iterator.Element?",
-                  "usr": "s:Sq",
                   "children": [
                     {
                       "kind": "TypeNameAlias",
@@ -124313,63 +138471,75 @@
                         }
                       ]
                     }
-                  ]
+                  ],
+                  "usr": "s:Sq"
                 }
-              ]
+              ],
+              "declKind": "Func",
+              "usr": "s:s12Zip2SequenceV8IteratorV4next7ElementQz_AFQy_tSgyF",
+              "moduleName": "Swift",
+              "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
+              "declAttributes": [
+                "Inlinable"
+              ],
+              "mutating": true
             }
+          ],
+          "declKind": "Struct",
+          "usr": "s:s12Zip2SequenceV8IteratorV",
+          "moduleName": "Swift",
+          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
+          "declAttributes": [
+            "FixedLayout"
+          ],
+          "conformingProtocols": [
+            "IteratorProtocol"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Stream1",
           "printedName": "Stream1",
-          "declKind": "TypeAlias",
-          "usr": "s:s12Zip2SequenceV7Stream1a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Sequence1.Iterator"
             }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s12Zip2SequenceV7Stream1a",
+          "moduleName": "Swift",
+          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Stream2",
           "printedName": "Stream2",
-          "declKind": "TypeAlias",
-          "usr": "s:s12Zip2SequenceV7Stream2a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-          "deprecated": true,
-          "declAttributes": [
-            "Available"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "DependentMember",
               "printedName": "Sequence2.Iterator"
             }
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s12Zip2SequenceV7Stream2a",
+          "moduleName": "Swift",
+          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
+          "deprecated": true,
+          "declAttributes": [
+            "Available"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "Element",
           "printedName": "Element",
-          "declKind": "TypeAlias",
-          "usr": "s:s12Zip2SequenceV7Elementa",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
@@ -124388,20 +138558,16 @@
                 }
               ]
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s12Zip2SequenceV7Elementa",
+          "moduleName": "Swift",
+          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>"
         },
         {
           "kind": "Function",
           "name": "makeIterator",
           "printedName": "makeIterator()",
-          "declKind": "Func",
-          "usr": "s:s12Zip2SequenceV12makeIteratorAB0D0Vyxq__GyF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
-          "declAttributes": [
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
@@ -124409,23 +138575,24 @@
               "printedName": "Zip2Sequence<Sequence1, Sequence2>.Iterator",
               "usr": "s:s12Zip2SequenceV8IteratorV"
             }
+          ],
+          "declKind": "Func",
+          "usr": "s:s12Zip2SequenceV12makeIteratorAB0D0Vyxq__GyF",
+          "moduleName": "Swift",
+          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
+          "declAttributes": [
+            "Inlinable"
           ]
         },
         {
           "kind": "TypeAlias",
           "name": "SubSequence",
           "printedName": "SubSequence",
-          "declKind": "TypeAlias",
-          "usr": "s:s12Zip2SequenceV03SubB0a",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
           "children": [
             {
               "kind": "TypeNominal",
               "name": "AnySequence",
               "printedName": "AnySequence<(Sequence1.Element, Sequence2.Element)>",
-              "usr": "s:s11AnySequenceV",
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -124444,66 +138611,55 @@
                     }
                   ]
                 }
-              ]
+              ],
+              "usr": "s:s11AnySequenceV"
             }
-          ]
+          ],
+          "declKind": "TypeAlias",
+          "usr": "s:s12Zip2SequenceV03SubB0a",
+          "moduleName": "Swift",
+          "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
+          "implicit": true
         }
+      ],
+      "declKind": "Struct",
+      "usr": "s:s12Zip2SequenceV",
+      "moduleName": "Swift",
+      "genericSig": "<Sequence1, Sequence2 where Sequence1 : Sequence, Sequence2 : Sequence>",
+      "declAttributes": [
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence"
       ]
     },
     {
       "kind": "TypeDecl",
       "name": "ArrayProtocol",
       "printedName": "ArrayProtocol",
-      "declKind": "Protocol",
-      "usr": "s:s13ArrayProtocolP",
-      "location": "",
-      "moduleName": "Swift",
-      "genericSig": "<Self : ExpressibleByArrayLiteral, Self : RangeReplaceableCollection, Self._Buffer : _ArrayBufferProtocol>",
-      "conformingProtocols": [
-        "RangeReplaceableCollection",
-        "ExpressibleByArrayLiteral",
-        "Collection",
-        "Sequence"
-      ],
-      "declAttributes": [
-        "UsableFromInline"
-      ],
       "children": [
         {
           "kind": "Function",
           "name": "filter",
           "printedName": "filter(_:)",
-          "declKind": "Func",
-          "usr": "s:s13ArrayProtocolPsE6filterySay7ElementQzGSbAEKXEKF",
-          "location": "",
-          "moduleName": "Swift",
-          "genericSig": "<Self where Self : ArrayProtocol>",
-          "throwing": true,
-          "declAttributes": [
-            "Rethrows",
-            "Inlinable"
-          ],
           "children": [
             {
               "kind": "TypeNominal",
               "name": "Array",
               "printedName": "[Self.Element]",
-              "usr": "s:Sa",
               "children": [
                 {
                   "kind": "TypeNominal",
                   "name": "DependentMember",
                   "printedName": "Self.Element"
                 }
-              ]
+              ],
+              "usr": "s:Sa"
             },
             {
               "kind": "TypeFunc",
               "name": "Function",
               "printedName": "(Self.Element) throws -> Bool",
-              "typeAttributes": [
-                "noescape"
-              ],
               "children": [
                 {
                   "kind": "TypeNominal",
@@ -124523,10 +138679,187 @@
                     }
                   ]
                 }
+              ],
+              "typeAttributes": [
+                "noescape"
               ]
             }
-          ]
+          ],
+          "declKind": "Func",
+          "usr": "s:s13ArrayProtocolPsE6filterySay7ElementQzGSbAEKXEKF",
+          "moduleName": "Swift",
+          "genericSig": "<Self where Self : ArrayProtocol>",
+          "declAttributes": [
+            "Rethrows",
+            "Inlinable"
+          ],
+          "throwing": true
         }
+      ],
+      "declKind": "Protocol",
+      "usr": "s:s13ArrayProtocolP",
+      "moduleName": "Swift",
+      "genericSig": "<Self : ExpressibleByArrayLiteral, Self : RangeReplaceableCollection, Self._Buffer : _ArrayBufferProtocol>",
+      "isInternal": true,
+      "declAttributes": [
+        "UsableFromInline"
+      ],
+      "conformingProtocols": [
+        "RangeReplaceableCollection",
+        "ExpressibleByArrayLiteral",
+        "Collection",
+        "Sequence"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Word",
+      "printedName": "Word",
+      "declKind": "Struct",
+      "usr": "s:s13_UnsafeBitsetV4WordV",
+      "moduleName": "Swift",
+      "isInternal": true,
+      "declAttributes": [
+        "UsableFromInline",
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Sequence",
+        "IteratorProtocol"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Index",
+      "printedName": "Index",
+      "declKind": "Struct",
+      "usr": "s:s16_CocoaDictionaryV5IndexV",
+      "moduleName": "Swift",
+      "isInternal": true,
+      "declAttributes": [
+        "UsableFromInline",
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Comparable"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Iterator",
+      "printedName": "Iterator",
+      "declKind": "Class",
+      "usr": "s:s16_CocoaDictionaryV8IteratorC",
+      "moduleName": "Swift",
+      "isInternal": true,
+      "declAttributes": [
+        "Final",
+        "UsableFromInline"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Bucket",
+      "printedName": "Bucket",
+      "declKind": "Struct",
+      "usr": "s:s10_HashTableV6BucketV",
+      "moduleName": "Swift",
+      "isInternal": true,
+      "declAttributes": [
+        "UsableFromInline",
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Comparable"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Index",
+      "printedName": "Index",
+      "declKind": "Struct",
+      "usr": "s:s10_HashTableV5IndexV",
+      "moduleName": "Swift",
+      "isInternal": true,
+      "declAttributes": [
+        "FixedLayout",
+        "UsableFromInline"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Comparable"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Iterator",
+      "printedName": "Iterator",
+      "declKind": "Struct",
+      "usr": "s:s17_NativeDictionaryV8IteratorV",
+      "moduleName": "Swift",
+      "genericSig": "<Key, Value where Key : Hashable>",
+      "isInternal": true,
+      "declAttributes": [
+        "FixedLayout",
+        "UsableFromInline"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Iterator",
+      "printedName": "Iterator",
+      "declKind": "Struct",
+      "usr": "s:s10_NativeSetV8IteratorV",
+      "moduleName": "Swift",
+      "genericSig": "<Element where Element : Hashable>",
+      "isInternal": true,
+      "declAttributes": [
+        "FixedLayout",
+        "UsableFromInline"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Index",
+      "printedName": "Index",
+      "declKind": "Struct",
+      "usr": "s:s9_CocoaSetV5IndexV",
+      "moduleName": "Swift",
+      "isInternal": true,
+      "declAttributes": [
+        "UsableFromInline",
+        "FixedLayout"
+      ],
+      "conformingProtocols": [
+        "Equatable",
+        "Comparable"
+      ]
+    },
+    {
+      "kind": "TypeDecl",
+      "name": "Iterator",
+      "printedName": "Iterator",
+      "declKind": "Class",
+      "usr": "s:s9_CocoaSetV8IteratorC",
+      "moduleName": "Swift",
+      "isInternal": true,
+      "declAttributes": [
+        "Final",
+        "UsableFromInline"
+      ],
+      "conformingProtocols": [
+        "IteratorProtocol"
       ]
     }
   ]
diff --git a/test/api-digester/Outputs/Cake-abi.txt b/test/api-digester/Outputs/Cake-abi.txt
index 6ed18d8..f3a5c3b 100644
--- a/test/api-digester/Outputs/Cake-abi.txt
+++ b/test/api-digester/Outputs/Cake-abi.txt
@@ -10,6 +10,7 @@
 cake1: Class C3 has been removed
 cake1: Constructor Somestruct2.init(_:) has been removed
 cake1: Constructor fixedLayoutStruct.init(b:a:) has been removed
+cake1: Constructor fixedLayoutStruct2.init(NoLongerWithFixedBinaryOrder:) has been removed
 cake1: Func C4.foo() has been removed
 cake1: Func RequiementChanges.removedFunc() has been removed
 cake1: Subscript RemoveSetters.subscript(_:) has removed its setter
@@ -53,6 +54,8 @@
 cake1: EnumElement FrozenKind.Rigid in a non-resilient type changes position from 2 to 1
 cake1: Var fixedLayoutStruct.a in a non-resilient type changes position from 1 to 0
 cake1: Var fixedLayoutStruct.b in a non-resilient type changes position from 0 to 1
+cake1: Var fixedLayoutStruct2.BecomeFixedBinaryOrder is now a property with fixed layout order
+cake1: Var fixedLayoutStruct2.NoLongerWithFixedBinaryOrder is no longer a property with fixed layout order
 cake2: EnumElement FrozenKind.AddedCase is added to a non-resilient type
 cake2: Var fixedLayoutStruct.c is added to a non-resilient type
 cake2: Var fixedLayoutStruct.lazy_d.storage is added to a non-resilient type
@@ -66,6 +69,7 @@
 
 /* Protocol Requirement Change */
 cake1: AssociatedType AssociatedTypePro.T1 has removed default type Int
+cake2: AssociatedType RequiementChanges.addedTypeWithDefault has been added as a protocol requirement
 cake2: AssociatedType RequiementChanges.addedTypeWithoutDefault has been added as a protocol requirement
 cake2: Func RequiementChanges.addedFunc() has been added as a protocol requirement
 cake2: Var RequiementChanges.addedVar has been added as a protocol requirement
diff --git a/test/api-digester/Outputs/Cake.txt b/test/api-digester/Outputs/Cake.txt
index af4ed30..cb9910a 100644
--- a/test/api-digester/Outputs/Cake.txt
+++ b/test/api-digester/Outputs/Cake.txt
@@ -9,6 +9,7 @@
 cake1: AssociatedType RequiementChanges.removedType has been removed
 cake1: Constructor Somestruct2.init(_:) has been removed
 cake1: Constructor fixedLayoutStruct.init(b:a:) has been removed
+cake1: Constructor fixedLayoutStruct2.init(NoLongerWithFixedBinaryOrder:) has been removed
 cake1: Func C4.foo() has been removed
 cake1: Func RequiementChanges.removedFunc() has been removed
 cake1: Subscript RemoveSetters.subscript(_:) has removed its setter
@@ -46,6 +47,7 @@
 
 /* Protocol Requirement Change */
 cake1: AssociatedType AssociatedTypePro.T1 has removed default type Int
+cake2: AssociatedType RequiementChanges.addedTypeWithDefault has been added as a protocol requirement
 cake2: AssociatedType RequiementChanges.addedTypeWithoutDefault has been added as a protocol requirement
 cake2: Func RequiementChanges.addedFunc() has been added as a protocol requirement
 cake2: Var RequiementChanges.addedVar has been added as a protocol requirement
diff --git a/test/api-digester/Outputs/cake-abi.json b/test/api-digester/Outputs/cake-abi.json
index 3499c77..54a3bb2 100644
--- a/test/api-digester/Outputs/cake-abi.json
+++ b/test/api-digester/Outputs/cake-abi.json
@@ -840,6 +840,49 @@
           "hasStorage": true
         },
         {
+          "kind": "Var",
+          "name": "unavailableProperty",
+          "printedName": "unavailableProperty",
+          "children": [
+            {
+              "kind": "TypeNominal",
+              "name": "Int",
+              "printedName": "Int",
+              "usr": "s:Si"
+            },
+            {
+              "kind": "Getter",
+              "name": "_",
+              "printedName": "_()",
+              "children": [
+                {
+                  "kind": "TypeNominal",
+                  "name": "Int",
+                  "printedName": "Int",
+                  "usr": "s:Si"
+                }
+              ],
+              "declKind": "Accessor",
+              "usr": "s:4cake17fixedLayoutStructV19unavailablePropertySivg",
+              "moduleName": "cake",
+              "implicit": true,
+              "declAttributes": [
+                "Transparent"
+              ]
+            }
+          ],
+          "declKind": "Var",
+          "usr": "s:4cake17fixedLayoutStructV19unavailablePropertySivp",
+          "moduleName": "cake",
+          "declAttributes": [
+            "HasInitialValue",
+            "Available"
+          ],
+          "fixedbinaryorder": 3,
+          "isLet": true,
+          "hasStorage": true
+        },
+        {
           "kind": "Constructor",
           "name": "init",
           "printedName": "init(a:b:c:)",
@@ -1148,6 +1191,16 @@
       "hasStorage": true
     },
     {
+      "kind": "OperatorDecl",
+      "name": "..*..",
+      "printedName": "..*..",
+      "declKind": "InfixOperator",
+      "moduleName": "cake",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
       "kind": "TypeDecl",
       "name": "Int",
       "printedName": "Int",
diff --git a/test/api-digester/Outputs/cake.json b/test/api-digester/Outputs/cake.json
index 6007835..ab0ef71 100644
--- a/test/api-digester/Outputs/cake.json
+++ b/test/api-digester/Outputs/cake.json
@@ -1146,6 +1146,16 @@
       "hasStorage": true
     },
     {
+      "kind": "OperatorDecl",
+      "name": "..*..",
+      "printedName": "..*..",
+      "declKind": "InfixOperator",
+      "moduleName": "cake",
+      "declAttributes": [
+        "Infix"
+      ]
+    },
+    {
       "kind": "TypeDecl",
       "name": "Int",
       "printedName": "Int",
diff --git a/test/api-digester/Outputs/stability-stdlib-abi.swift.expected b/test/api-digester/Outputs/stability-stdlib-abi.swift.expected
new file mode 100644
index 0000000..e548788
--- /dev/null
+++ b/test/api-digester/Outputs/stability-stdlib-abi.swift.expected
@@ -0,0 +1,16 @@
+
+/* Generic Signature Changes */
+
+/* RawRepresentable Changes */
+
+/* Removed Decls */
+
+/* Moved Decls */
+
+/* Renamed Decls */
+
+/* Type Changes */
+
+/* Decl Attribute changes */
+
+/* Protocol Requirement Changes */
diff --git a/test/api-digester/Outputs/stability-stdlib-source.swift.expected b/test/api-digester/Outputs/stability-stdlib-source.swift.expected
new file mode 100644
index 0000000..e548788
--- /dev/null
+++ b/test/api-digester/Outputs/stability-stdlib-source.swift.expected
@@ -0,0 +1,16 @@
+
+/* Generic Signature Changes */
+
+/* RawRepresentable Changes */
+
+/* Removed Decls */
+
+/* Moved Decls */
+
+/* Renamed Decls */
+
+/* Type Changes */
+
+/* Decl Attribute changes */
+
+/* Protocol Requirement Changes */
diff --git a/test/api-digester/source-stability.swift b/test/api-digester/source-stability.swift
deleted file mode 100644
index bef7315..0000000
--- a/test/api-digester/source-stability.swift
+++ /dev/null
@@ -1,9 +0,0 @@
-// REQUIRES: OS=macosx
-// RUN: %empty-directory(%t.tmp)
-// mkdir %t.tmp/module-cache && mkdir %t.tmp/dummy.sdk
-// RUN: %api-digester -dump-sdk -module Swift -o %t.tmp/current-stdlib.json -module-cache-path %t.tmp/module-cache -sdk %t.tmp/dummy.sdk
-// RUN: %api-digester -diagnose-sdk -input-paths %S/stdlib-stable.json -input-paths %t.tmp/current-stdlib.json >> %t.tmp/changes.txt
-// RUN: %clang -E -P -x c %S/source-stability.swift.expected -o - | sed '/^\s*$/d' > %t.tmp/source-stability.swift.expected
-// RUN: %clang -E -P -x c %t.tmp/changes.txt -o - | sed '/^\s*$/d' > %t.tmp/changes.txt.tmp
-// RUN: diff -u %t.tmp/source-stability.swift.expected %t.tmp/changes.txt.tmp
-
diff --git a/test/api-digester/source-stability.swift.expected b/test/api-digester/source-stability.swift.expected
deleted file mode 100644
index 1246da8..0000000
--- a/test/api-digester/source-stability.swift.expected
+++ /dev/null
@@ -1,173 +0,0 @@
-
-/* Generic Signature Changes */
-Constructor BinaryFloatingPoint.init(_:) has generic signature change from <Self, Source where Self : BinaryFloatingPoint, Source : BinaryInteger> to <Self, Source where Self : BinaryFloatingPoint, Source : BinaryInteger, Self.RawSignificand : FixedWidthInteger>
-Constructor BinaryFloatingPoint.init(exactly:) has generic signature change from <Self, Source where Self : BinaryFloatingPoint, Source : BinaryInteger> to <Self, Source where Self : BinaryFloatingPoint, Source : BinaryInteger, Self.RawSignificand : FixedWidthInteger>
-Constructor Double.init(_:) has generic signature change from to <Source where Source : BinaryInteger>
-Constructor Float.init(_:) has generic signature change from to <Source where Source : BinaryInteger>
-Constructor Float80.init(_:) has generic signature change from to <Source where Source : BinaryInteger>
-Func Substring.replaceSubrange(_:with:) has generic signature change from <C where C : Collection, C.Element == Character> to <C where C : Collection, C.Element == Substring.Iterator.Element>
-Protocol BinaryInteger has generic signature change from <Self : CustomStringConvertible, Self : Hashable, Self : Numeric, Self : Strideable, Self.Magnitude : BinaryInteger, Self.Magnitude == Self.Magnitude.Magnitude, Self.Words : Sequence, Self.Words.Element == UInt> to <Self : CustomStringConvertible, Self : Hashable, Self : Numeric, Self : Strideable, Self.Magnitude : BinaryInteger, Self.Magnitude == Self.Magnitude.Magnitude, Self.Words : RandomAccessCollection, Self.Words.Element == UInt, Self.Words.Index == Int>
-/* RawRepresentable Changes */
-
-/* Removed Decls */
-Constructor Double.init(exactly:) has been removed
-Constructor Float.init(exactly:) has been removed
-Constructor Float80.init(exactly:) has been removed
-Constructor FloatingPoint.init(_:) has been removed
-Constructor Int.init(truncatingBitPattern:) has been removed
-Constructor Int16.init(truncatingBitPattern:) has been removed
-Constructor Int32.init(truncatingBitPattern:) has been removed
-Constructor Int8.init(truncatingBitPattern:) has been removed
-Constructor String.init(_:obsoletedInSwift4:) has been removed
-Constructor UInt.init(truncatingBitPattern:) has been removed
-Constructor UInt16.init(truncatingBitPattern:) has been removed
-Constructor UInt32.init(truncatingBitPattern:) has been removed
-Constructor UInt8.init(truncatingBitPattern:) has been removed
-Func BinaryInteger.toIntMax() has been removed
-Func FixedWidthInteger.addWithOverflow(_:_:) has been removed
-Func FixedWidthInteger.divideWithOverflow(_:_:) has been removed
-Func FixedWidthInteger.multiplyWithOverflow(_:_:) has been removed
-Func FixedWidthInteger.remainderWithOverflow(_:_:) has been removed
-Func FixedWidthInteger.subtractWithOverflow(_:_:) has been removed
-Func FixedWidthInteger.unsafeAdding(_:) has been removed
-Func FixedWidthInteger.unsafeDivided(by:) has been removed
-Func FixedWidthInteger.unsafeMultiplied(by:) has been removed
-Func FixedWidthInteger.unsafeSubtracting(_:) has been removed
-Func FloatingPoint.abs(_:) has been removed (deprecated)
-Func FloatingPoint.add(_:) has been removed
-Func FloatingPoint.adding(_:) has been removed
-Func FloatingPoint.divide(by:) has been removed
-Func FloatingPoint.divided(by:) has been removed
-Func FloatingPoint.multiplied(by:) has been removed
-Func FloatingPoint.multiply(by:) has been removed
-Func FloatingPoint.negated() has been removed
-Func FloatingPoint.subtract(_:) has been removed
-Func FloatingPoint.subtracting(_:) has been removed
-Func Int.toUIntMax() has been removed
-Func Int16.toUIntMax() has been removed
-Func Int32.toUIntMax() has been removed
-Func Int64.toUIntMax() has been removed
-Func Int8.toUIntMax() has been removed
-Func Sequence.flatMap(_:) has been removed
-Func SignedNumeric.abs(_:) has been removed
-Func String.UTF16View.distance(from:to:) has been removed
-Func String.UTF16View.index(_:offsetBy:) has been removed
-Func String.UTF16View.index(after:) has been removed
-Func String.UTF8View.distance(from:to:) has been removed
-Func String.UTF8View.index(_:offsetBy:) has been removed
-Func String.UTF8View.index(after:) has been removed
-Func String.UnicodeScalarView.distance(from:to:) has been removed
-Func String.UnicodeScalarView.index(_:offsetBy:) has been removed
-Func String.UnicodeScalarView.index(after:) has been removed
-Func String.UnicodeScalarView.popFirst() has been removed (deprecated)
-Func String.popFirst() has been removed (deprecated)
-Func UInt.toIntMax() has been removed
-Func UInt16.toIntMax() has been removed
-Func UInt32.toIntMax() has been removed
-Func UInt64.toIntMax() has been removed
-Func UInt8.toIntMax() has been removed
-Func UnsignedInteger.toUIntMax() has been removed
-TypeAlias AbsoluteValuable has been removed
-TypeAlias BitwiseOperations has been removed (deprecated)
-TypeAlias IntMax has been removed
-TypeAlias Integer has been removed
-TypeAlias IntegerArithmetic has been removed
-TypeAlias SignedNumber has been removed
-TypeAlias StringProtocol.UTF16Index has been removed (deprecated)
-TypeAlias StringProtocol.UTF8Index has been removed (deprecated)
-TypeAlias StringProtocol.UnicodeScalarIndex has been removed (deprecated)
-TypeAlias UIntMax has been removed
-Var FixedWidthInteger.allZeros has been removed (deprecated)
-
-/* Moved Decls */
-
-/* Renamed Decls */
-Func Dictionary.filter(_:obsoletedInSwift4:) has been renamed to Func Dictionary.filter(_:)
-Func Set.filter(_:obsoletedInSwift4:) has been renamed to Func Set.filter(_:)
-
-/* Type Changes */
-Constructor Double.init(_:) has parameter 0 type change from UInt8 to Source
-Constructor Float.init(_:) has parameter 0 type change from UInt8 to Source
-Constructor Float80.init(_:) has parameter 0 type change from UInt8 to Source
-Constructor Mirror.init(_:children:displayStyle:ancestorRepresentation:) has parameter 1 type change from DictionaryLiteral<String, Any> to KeyValuePairs<String, Any>
-Constructor String.init(_:) has return type change from String? to String
-Func Dictionary.filter(_:obsoletedInSwift4:) has return type change from [Dictionary<Key, Value>.Element] to [Dictionary<Key, Value>.Key : Dictionary<Key, Value>.Value]
-Func Dictionary.makeIterator() has return type change from DictionaryIterator<Dictionary<Key, Value>.Key, Dictionary<Key, Value>.Value> to Dictionary<Key, Value>.Iterator
-Func Set.filter(_:obsoletedInSwift4:) has return type change from [Set<Element>.Element] to Set<Element>
-Func Set.makeIterator() has return type change from SetIterator<Element> to Set<Element>.Iterator
-Var Dictionary.keys has declared type change from LazyMapCollection<[Key : Value], Key> to Dictionary<Key, Value>.Keys
-Var Dictionary.values has declared type change from LazyMapCollection<[Key : Value], Value> to Dictionary<Key, Value>.Values
-
-
-/* Decl Attribute changes */
-
-/* Protocol Requirement Changes */
-AssociatedType BinaryFloatingPoint.RawExponent has been added as a protocol requirement
-AssociatedType BinaryFloatingPoint.RawSignificand has been added as a protocol requirement
-AssociatedType BinaryInteger.Words has been added as a protocol requirement
-AssociatedType CaseIterable.AllCases has been added as a protocol requirement
-AssociatedType Collection.Index has been added as a protocol requirement
-AssociatedType ExpressibleByArrayLiteral.ArrayLiteralElement has been added as a protocol requirement
-AssociatedType ExpressibleByBooleanLiteral.BooleanLiteralType has been added as a protocol requirement
-AssociatedType ExpressibleByDictionaryLiteral.Key has been added as a protocol requirement
-AssociatedType ExpressibleByDictionaryLiteral.Value has been added as a protocol requirement
-AssociatedType ExpressibleByExtendedGraphemeClusterLiteral.ExtendedGraphemeClusterLiteralType has been added as a protocol requirement
-AssociatedType ExpressibleByFloatLiteral.FloatLiteralType has been added as a protocol requirement
-AssociatedType ExpressibleByIntegerLiteral.IntegerLiteralType has been added as a protocol requirement
-AssociatedType ExpressibleByStringLiteral.StringLiteralType has been added as a protocol requirement
-AssociatedType ExpressibleByUnicodeScalarLiteral.UnicodeScalarLiteralType has been added as a protocol requirement
-AssociatedType FloatingPoint.Exponent has been added as a protocol requirement
-AssociatedType IteratorProtocol.Element has been added as a protocol requirement
-AssociatedType KeyedDecodingContainerProtocol.Key has been added as a protocol requirement
-AssociatedType KeyedEncodingContainerProtocol.Key has been added as a protocol requirement
-AssociatedType Numeric.Magnitude has been added as a protocol requirement
-AssociatedType RangeExpression.Bound has been added as a protocol requirement
-AssociatedType RawRepresentable.RawValue has been added as a protocol requirement
-AssociatedType Sequence.Element has been added as a protocol requirement
-AssociatedType Sequence.Iterator has been added as a protocol requirement
-AssociatedType SetAlgebra.Element has been added as a protocol requirement
-AssociatedType Strideable.Stride has been added as a protocol requirement
-AssociatedType StringProtocol.UTF16View has been added as a protocol requirement
-AssociatedType StringProtocol.UTF8View has been added as a protocol requirement
-AssociatedType StringProtocol.UnicodeScalarView has been added as a protocol requirement
-AssociatedType _SequenceWrapper.Base has been added as a protocol requirement
-
-
-// These operator changes are false positive because the baseline doesn't have operators.
-Func BinaryInteger.%(_:_:) has been added as a protocol requirement
-Func BinaryInteger.%=(_:_:) has been added as a protocol requirement
-Func BinaryInteger.&(_:_:) has been added as a protocol requirement
-Func BinaryInteger.&=(_:_:) has been added as a protocol requirement
-Func BinaryInteger.<<(_:_:) has been added as a protocol requirement
-Func BinaryInteger.<<=(_:_:) has been added as a protocol requirement
-Func BinaryInteger.>>(_:_:) has been added as a protocol requirement
-Func BinaryInteger.>>=(_:_:) has been added as a protocol requirement
-Func BinaryInteger.\/(_:_:) has been added as a protocol requirement
-Func BinaryInteger.\/=(_:_:) has been added as a protocol requirement
-Func BinaryInteger.^(_:_:) has been added as a protocol requirement
-Func BinaryInteger.^=(_:_:) has been added as a protocol requirement
-Func BinaryInteger.isMultiple(of:) has been added as a protocol requirement
-Func BinaryInteger.|(_:_:) has been added as a protocol requirement
-Func BinaryInteger.|=(_:_:) has been added as a protocol requirement
-Func BinaryInteger.~(_:) has been added as a protocol requirement
-Func Comparable.<(_:_:) has been added as a protocol requirement
-Func Comparable.<=(_:_:) has been added as a protocol requirement
-Func Comparable.>(_:_:) has been added as a protocol requirement
-Func Comparable.>=(_:_:) has been added as a protocol requirement
-Func Equatable.==(_:_:) has been added as a protocol requirement
-Func FixedWidthInteger.&<<(_:_:) has been added as a protocol requirement
-Func FixedWidthInteger.&<<=(_:_:) has been added as a protocol requirement
-Func FixedWidthInteger.&>>(_:_:) has been added as a protocol requirement
-Func FixedWidthInteger.&>>=(_:_:) has been added as a protocol requirement
-Func FloatingPoint.\/(_:_:) has been added as a protocol requirement
-Func FloatingPoint.\/=(_:_:) has been added as a protocol requirement
-Func Numeric.*(_:_:) has been added as a protocol requirement
-Func Numeric.*=(_:_:) has been added as a protocol requirement
-Func Numeric.+(_:_:) has been added as a protocol requirement
-Func Numeric.+=(_:_:) has been added as a protocol requirement
-Func Numeric.-(_:_:) has been added as a protocol requirement
-Func Numeric.-=(_:_:) has been added as a protocol requirement
-Func SignedNumeric.-(_:) has been added as a protocol requirement
-
-// The subscript changes are bogus because we don't have subscript decls in the baseline.
-Subscript Collection.subscript(_:) has been added as a protocol requirement
diff --git a/test/api-digester/stability-stdlib-abi.swift b/test/api-digester/stability-stdlib-abi.swift
new file mode 100644
index 0000000..cd80332
--- /dev/null
+++ b/test/api-digester/stability-stdlib-abi.swift
@@ -0,0 +1,8 @@
+// REQUIRES: OS=macosx
+// RUN: %empty-directory(%t.tmp)
+// mkdir %t.tmp/module-cache && mkdir %t.tmp/dummy.sdk
+// RUN: %api-digester -dump-sdk -module Swift -o %t.tmp/current-stdlib.json -module-cache-path %t.tmp/module-cache -sdk %t.tmp/dummy.sdk -abi
+// RUN: %api-digester -diagnose-sdk -input-paths %S/Inputs/stdlib-stable-abi.json -input-paths %t.tmp/current-stdlib.json -abi >> %t.tmp/changes.txt
+// RUN: %clang -E -P -x c %S/Outputs/stability-stdlib-abi.swift.expected -o - | sed '/^\s*$/d' > %t.tmp/stability-stdlib-abi.swift.expected
+// RUN: %clang -E -P -x c %t.tmp/changes.txt -o - | sed '/^\s*$/d' > %t.tmp/changes.txt.tmp
+// RUN: diff -u %t.tmp/stability-stdlib-abi.swift.expected %t.tmp/changes.txt.tmp
diff --git a/test/api-digester/stability-stdlib-source.swift b/test/api-digester/stability-stdlib-source.swift
new file mode 100644
index 0000000..67845bd
--- /dev/null
+++ b/test/api-digester/stability-stdlib-source.swift
@@ -0,0 +1,8 @@
+// REQUIRES: OS=macosx
+// RUN: %empty-directory(%t.tmp)
+// mkdir %t.tmp/module-cache && mkdir %t.tmp/dummy.sdk
+// RUN: %api-digester -dump-sdk -module Swift -o %t.tmp/current-stdlib.json -module-cache-path %t.tmp/module-cache -sdk %t.tmp/dummy.sdk
+// RUN: %api-digester -diagnose-sdk -input-paths %S/Inputs/stdlib-stable.json -input-paths %t.tmp/current-stdlib.json >> %t.tmp/changes.txt
+// RUN: %clang -E -P -x c %S/Outputs/stability-stdlib-source.swift.expected -o - | sed '/^\s*$/d' > %t.tmp/stability-stdlib-source.swift.expected
+// RUN: %clang -E -P -x c %t.tmp/changes.txt -o - | sed '/^\s*$/d' > %t.tmp/changes.txt.tmp
+// RUN: diff -u %t.tmp/stability-stdlib-source.swift.expected %t.tmp/changes.txt.tmp
diff --git a/tools/SourceKit/CMakeLists.txt b/tools/SourceKit/CMakeLists.txt
index 304a427..b950502 100644
--- a/tools/SourceKit/CMakeLists.txt
+++ b/tools/SourceKit/CMakeLists.txt
@@ -34,6 +34,11 @@
   set(CMAKE_OSX_DEPLOYMENT_TARGET "")
 endif()
 
+# If we were don't have XPC, just build inproc.
+if("${CMAKE_SYSTEM_NAME}" STREQUAL "Darwin" AND NOT HAVE_XPC_H)
+  set(SWIFT_SOURCEKIT_USE_INPROC_LIBRARY TRUE)
+endif()
+
 # Now include AddSwiftSourceKit
 include(AddSwiftSourceKit)
 
@@ -93,6 +98,12 @@
 if("${CMAKE_SYSTEM_NAME}" STREQUAL "Linux")
   set(SOURCEKIT_DEFAULT_TARGET_SDK "LINUX")
   if(SWIFT_BUILD_SOURCEKIT)
+    if(SWIFT_BUILD_STDLIB)
+      set(SOURCEKIT_LIBDISPATCH_ENABLE_SWIFT YES)
+    else()
+      set(SOURCEKIT_LIBDISPATCH_ENABLE_SWIFT NO)
+    endif()
+
     include(ExternalProject)
     ExternalProject_Add(libdispatch
                         SOURCE_DIR
@@ -106,7 +117,7 @@
                           -DCMAKE_MAKE_PROGRAM=${CMAKE_MAKE_PROGRAM}
                           -DCMAKE_SWIFT_COMPILER=$<TARGET_FILE:swift>c
                           -DCMAKE_INSTALL_PREFIX=<INSTALL_DIR>
-                          -DENABLE_SWIFT=YES
+                          -DENABLE_SWIFT=${SOURCEKIT_LIBDISPATCH_ENABLE_SWIFT}
                         BUILD_BYPRODUCTS
                           ${SWIFT_PATH_TO_LIBDISPATCH_BUILD}/src/${CMAKE_SHARED_LIBRARY_PREFIX}dispatch${CMAKE_SHARED_LIBRARY_SUFFIX}
                           ${SWIFT_PATH_TO_LIBDISPATCH_BUILD}/${CMAKE_STATIC_LIBRARY_PREFIX}BlocksRuntime${CMAKE_STATIC_LIBRARY_SUFFIX}
@@ -126,13 +137,16 @@
     include_directories(AFTER
                           ${SWIFT_PATH_TO_LIBDISPATCH_SOURCE}/src/BlocksRuntime
                           ${SWIFT_PATH_TO_LIBDISPATCH_SOURCE})
-    add_dependencies(libdispatch
-                       swift
-                       copy_shim_headers
-                       swiftCore-${SWIFT_SDK_${SWIFT_HOST_VARIANT_SDK}_LIB_SUBDIR}-${SWIFT_HOST_VARIANT_ARCH}
-                       swiftSwiftOnoneSupport-${SWIFT_SDK_${SWIFT_HOST_VARIANT_SDK}_LIB_SUBDIR}-${SWIFT_HOST_VARIANT_ARCH}
-                       swiftCore-swiftmodule-${SWIFT_SDK_${SWIFT_HOST_VARIANT_SDK}_LIB_SUBDIR}-${SWIFT_HOST_VARIANT_ARCH}
-                       swiftSwiftOnoneSupport-swiftmodule-${SWIFT_SDK_${SWIFT_HOST_VARIANT_SDK}_LIB_SUBDIR}-${SWIFT_HOST_VARIANT_ARCH})
+
+    if(SWIFT_BUILD_STDLIB)
+      add_dependencies(libdispatch
+                         swift
+                         copy_shim_headers
+                         swiftCore-${SWIFT_SDK_${SWIFT_HOST_VARIANT_SDK}_LIB_SUBDIR}-${SWIFT_HOST_VARIANT_ARCH}
+                         swiftSwiftOnoneSupport-${SWIFT_SDK_${SWIFT_HOST_VARIANT_SDK}_LIB_SUBDIR}-${SWIFT_HOST_VARIANT_ARCH}
+                         swiftCore-swiftmodule-${SWIFT_SDK_${SWIFT_HOST_VARIANT_SDK}_LIB_SUBDIR}-${SWIFT_HOST_VARIANT_ARCH}
+                         swiftSwiftOnoneSupport-swiftmodule-${SWIFT_SDK_${SWIFT_HOST_VARIANT_SDK}_LIB_SUBDIR}-${SWIFT_HOST_VARIANT_ARCH})
+    endif()
   endif()
 
   ExternalProject_Get_Property(libdispatch install_dir)
@@ -142,9 +156,13 @@
                           IMPORTED_LOCATION
                             ${SWIFT_PATH_TO_LIBDISPATCH_BUILD}/src/${CMAKE_SHARED_LIBRARY_PREFIX}dispatch${CMAKE_SHARED_LIBRARY_SUFFIX}
                           INTERFACE_INCLUDE_DIRECTORIES
-                            ${install_dir}/include
-                          IMPORTED_LINK_INTERFACE_LIBRARIES
-                            swiftCore-${SWIFT_SDK_${SWIFT_HOST_VARIANT_SDK}_LIB_SUBDIR}-${SWIFT_HOST_VARIANT_ARCH})
+                            ${install_dir}/include)
+  if(SWIFT_BUILD_STDLIB)
+    set_target_properties(dispatch
+                          PROPERTIES
+                            IMPORTED_LINK_INTERFACE_LIBRARIES
+                              swiftCore-${SWIFT_SDK_${SWIFT_HOST_VARIANT_SDK}_LIB_SUBDIR}-${SWIFT_HOST_VARIANT_ARCH})
+  endif()
 
   add_library(BlocksRuntime STATIC IMPORTED)
   set_target_properties(BlocksRuntime
diff --git a/tools/SourceKit/cmake/modules/AddSwiftSourceKit.cmake b/tools/SourceKit/cmake/modules/AddSwiftSourceKit.cmake
index c030879..27fe625 100644
--- a/tools/SourceKit/cmake/modules/AddSwiftSourceKit.cmake
+++ b/tools/SourceKit/cmake/modules/AddSwiftSourceKit.cmake
@@ -158,7 +158,7 @@
   set(prefixed_link_libraries)
   foreach(dep ${SOURCEKITLIB_LINK_LIBS})
     if("${dep}" MATCHES "^clang")
-      set(dep "${LLVM_LIBRARY_OUTPUT_INTDIR}/lib${dep}.a")
+      set(dep "${LLVM_LIBRARY_OUTPUT_INTDIR}/${CMAKE_STATIC_LIBRARY_PREFIX}${dep}${CMAKE_STATIC_LIBRARY_SUFFIX}")
     endif()
     list(APPEND prefixed_link_libraries "${dep}")
   endforeach()
diff --git a/tools/SourceKit/tools/sourcekitd/lib/API/CMakeLists.txt b/tools/SourceKit/tools/sourcekitd/lib/API/CMakeLists.txt
index 6baee8f..525c1d9 100644
--- a/tools/SourceKit/tools/sourcekitd/lib/API/CMakeLists.txt
+++ b/tools/SourceKit/tools/sourcekitd/lib/API/CMakeLists.txt
@@ -1,7 +1,3 @@
-# If we were going to build for APPLE but don't have XPC, just build inproc.
-if(APPLE AND NOT HAVE_XPC_H)
-  set(SWIFT_SOURCEKIT_USE_INPROC_LIBRARY TRUE)
-endif()
 
 set(sourcekitdAPI_sources
   CodeCompletionResultsArray.cpp
diff --git a/tools/swift-api-digester/ModuleAnalyzerNodes.cpp b/tools/swift-api-digester/ModuleAnalyzerNodes.cpp
index 0121329..7ff9cf5 100644
--- a/tools/swift-api-digester/ModuleAnalyzerNodes.cpp
+++ b/tools/swift-api-digester/ModuleAnalyzerNodes.cpp
@@ -39,7 +39,9 @@
   std::vector<TypeAttrKind> TypeAttrs;
 
   SDKNodeInitInfo(SDKContext &Ctx) : Ctx(Ctx) {}
+  SDKNodeInitInfo(SDKContext &Ctx, Decl *D);
   SDKNodeInitInfo(SDKContext &Ctx, ValueDecl *VD);
+  SDKNodeInitInfo(SDKContext &Ctx, OperatorDecl *D);
   SDKNodeInitInfo(SDKContext &Ctx, Type Ty, bool IsImplicitlyUnwrappedOptional,
                   bool hasDefaultArgument);
   SDKNode* createSDKNode(SDKNodeKind Kind);
@@ -55,6 +57,15 @@
 #undef ADD
 }
 
+void SDKNodeRoot::registerDescendant(SDKNode *D) {
+  // Operator doesn't have usr
+  if (isa<SDKNodeDeclOperator>(D))
+    return;
+  if (auto DD = dyn_cast<SDKNodeDecl>(D)) {
+    assert(!DD->getUsr().empty());
+    DescendantDeclTable[DD->getUsr()].insert(DD);
+  }
+}
 
 SDKNode::SDKNode(SDKNodeInitInfo Info, SDKNodeKind Kind): Ctx(Info.Ctx),
   Name(Info.Name), PrintedName(Info.PrintedName), TheKind(unsigned(Kind)) {}
@@ -86,12 +97,15 @@
 SDKNodeTypeAlias::SDKNodeTypeAlias(SDKNodeInitInfo Info):
   SDKNodeType(Info, SDKNodeKind::TypeAlias) {}
 
-SDKNodeDeclType::SDKNodeDeclType(SDKNodeInitInfo Info): 
+SDKNodeDeclType::SDKNodeDeclType(SDKNodeInitInfo Info):
   SDKNodeDecl(Info, SDKNodeKind::DeclType), SuperclassUsr(Info.SuperclassUsr),
   SuperclassNames(Info.SuperclassNames),
   ConformingProtocols(Info.ConformingProtocols),
   EnumRawTypeName(Info.EnumRawTypeName) {}
 
+SDKNodeDeclOperator::SDKNodeDeclOperator(SDKNodeInitInfo Info):
+  SDKNodeDecl(Info, SDKNodeKind::DeclOperator) {}
+
 SDKNodeDeclTypeAlias::SDKNodeDeclTypeAlias(SDKNodeInitInfo Info):
   SDKNodeDecl(Info, SDKNodeKind::DeclTypeAlias) {}
 
@@ -306,6 +320,7 @@
   case SDKNodeKind::TypeFunc:
   case SDKNodeKind::TypeAlias:
   case SDKNodeKind::DeclType:
+  case SDKNodeKind::DeclOperator:
     llvm_unreachable("Type Parent is wrong");
   case SDKNodeKind::DeclFunction:
   case SDKNodeKind::DeclConstructor:
@@ -678,7 +693,9 @@
         // them equal because we need to check definition orders.
         if (auto *LV = dyn_cast<SDKNodeDeclVar>(&L)) {
           if (auto *RV = dyn_cast<SDKNodeDeclVar>(&R)) {
-            if (LV->hasFixedBinaryOrder() && RV->hasFixedBinaryOrder()) {
+            if (LV->hasFixedBinaryOrder() != RV->hasFixedBinaryOrder())
+              return false;
+            if (LV->hasFixedBinaryOrder()) {
               if (LV->getFixedBinaryOrder() != RV->getFixedBinaryOrder())
                 return false;
             }
@@ -719,6 +736,7 @@
       }
       LLVM_FALLTHROUGH;
     }
+    case SDKNodeKind::DeclOperator:
     case SDKNodeKind::DeclTypeAlias: {
       auto Left = L.getAs<SDKNodeDecl>();
       auto Right = R.getAs<SDKNodeDecl>();
@@ -820,14 +838,14 @@
   return StringRef();
 }
 
-static StringRef calculateLocation(SDKContext &SDKCtx, ValueDecl *VD) {
+static StringRef calculateLocation(SDKContext &SDKCtx, Decl *D) {
   if (SDKCtx.getOpts().AvoidLocation)
     return StringRef();
-  auto &Ctx = VD->getASTContext();
+  auto &Ctx = D->getASTContext();
   auto &Importer = static_cast<ClangImporter &>(*Ctx.getClangModuleLoader());
 
   clang::SourceManager &SM = Importer.getClangPreprocessor().getSourceManager();
-  if (ClangNode CN = VD->getClangNode()) {
+  if (ClangNode CN = D->getClangNode()) {
     clang::SourceLocation Loc = CN.getLocation();
     Loc = SM.getFileLoc(Loc);
     if (Loc.isValid())
@@ -926,10 +944,10 @@
   }
 }
 
-static StringRef printGenericSignature(SDKContext &Ctx, ValueDecl *VD) {
+static StringRef printGenericSignature(SDKContext &Ctx, Decl *D) {
   llvm::SmallString<32> Result;
   llvm::raw_svector_ostream OS(Result);
-  if (auto *PD = dyn_cast<ProtocolDecl>(VD)) {
+  if (auto *PD = dyn_cast<ProtocolDecl>(D)) {
     if (PD->getRequirementSignature().empty())
       return StringRef();
     OS << "<";
@@ -949,7 +967,7 @@
     return Ctx.buffer(OS.str());
   }
 
-  if (auto *GC = VD->getAsGenericContext()) {
+  if (auto *GC = D->getAsGenericContext()) {
     if (auto *Sig = GC->getGenericSignature()) {
       if (Ctx.checkingABI())
         Sig->getCanonicalSignature()->print(OS);
@@ -1008,23 +1026,40 @@
   }
 }
 
+SDKNodeInitInfo::SDKNodeInitInfo(SDKContext &Ctx, Decl *D):
+      Ctx(Ctx), DKind(D->getKind()),
+      Location(calculateLocation(Ctx, D)),
+      ModuleName(D->getModuleContext()->getName().str()),
+      GenericSig(printGenericSignature(Ctx, D)),
+      IsImplicit(D->isImplicit()),
+      IsDeprecated(D->getAttrs().getDeprecated(D->getASTContext())) {
+  // Capture all attributes.
+  auto AllAttrs = D->getAttrs();
+  std::transform(AllAttrs.begin(), AllAttrs.end(), std::back_inserter(DeclAttrs),
+                 [](DeclAttribute *attr) { return attr->getKind(); });
+}
+
+SDKNodeInitInfo::SDKNodeInitInfo(SDKContext &Ctx, OperatorDecl *OD):
+    SDKNodeInitInfo(Ctx, cast<Decl>(OD)) {
+  Name = OD->getName().str();
+  PrintedName = OD->getName().str();
+}
+
 SDKNodeInitInfo::SDKNodeInitInfo(SDKContext &Ctx, ValueDecl *VD)
-    : Ctx(Ctx), DKind(VD->getKind()),
-      Name(VD->hasName() ? getEscapedName(VD->getBaseName()) : Ctx.buffer("_")),
-      PrintedName(getPrintedName(Ctx, VD)),
-      Usr(calculateUsr(Ctx, VD)), Location(calculateLocation(Ctx, VD)),
-      ModuleName(VD->getModuleContext()->getName().str()),
-      GenericSig(printGenericSignature(Ctx, VD)),
-      IsImplicit(VD->isImplicit()),
-      IsThrowing(isFuncThrowing(VD)), IsMutating(isFuncMutating(VD)),
-      IsStatic(VD->isStatic()),
-      IsDeprecated(VD->getAttrs().getDeprecated(VD->getASTContext())),
-      IsOverriding(VD->getOverriddenDecl()),
-      IsProtocolReq(isa<ProtocolDecl>(VD->getDeclContext()) && VD->isProtocolRequirement()),
-      IsOpen(VD->getFormalAccess() == AccessLevel::Open),
-      IsInternal(VD->getFormalAccess() < AccessLevel::Public),
-      SelfIndex(getSelfIndex(VD)), FixedBinaryOrder(getFixedBinaryOrder(VD)),
-      ReferenceOwnership(getReferenceOwnership(VD)) {
+    : SDKNodeInitInfo(Ctx, cast<Decl>(VD)) {
+  Name = VD->hasName() ? getEscapedName(VD->getBaseName()) : Ctx.buffer("_");
+  PrintedName = getPrintedName(Ctx, VD);
+  Usr = calculateUsr(Ctx, VD);
+  IsThrowing = isFuncThrowing(VD);
+  IsMutating = isFuncMutating(VD);
+  IsStatic = VD->isStatic();
+  IsOverriding = VD->getOverriddenDecl();
+  IsProtocolReq = isa<ProtocolDecl>(VD->getDeclContext()) && VD->isProtocolRequirement();
+  IsOpen = VD->getFormalAccess() == AccessLevel::Open;
+  IsInternal = VD->getFormalAccess() < AccessLevel::Public;
+  SelfIndex = getSelfIndex(VD);
+  FixedBinaryOrder = getFixedBinaryOrder(VD);
+  ReferenceOwnership = getReferenceOwnership(VD);
 
   // Calculate usr for its super class.
   if (auto *CD = dyn_cast_or_null<ClassDecl>(VD)) {
@@ -1036,11 +1071,6 @@
     }
   }
 
-  // Capture all attributes.
-  auto AllAttrs = VD->getAttrs();
-  std::transform(AllAttrs.begin(), AllAttrs.end(), std::back_inserter(DeclAttrs),
-                 [](DeclAttribute *attr) { return attr->getKind(); });
-
   // Get all protocol names this type decl conforms to.
   if (auto *NTD = dyn_cast<NominalTypeDecl>(VD)) {
     for (auto *P: NTD->getAllProtocols()) {
@@ -1172,29 +1202,30 @@
 
 bool swift::ide::api::
 SwiftDeclCollector::shouldIgnore(Decl *D, const Decl* Parent) {
+  if (Ctx.checkingABI()) {
+    if (auto *VD = dyn_cast<ValueDecl>(D)) {
+      // Private vars with fixed binary orders can have ABI-impact, so we should
+      // whitelist them if we're checking ABI.
+      if (getFixedBinaryOrder(VD).hasValue())
+        return false;
+      // Typealias should have no impact on ABI.
+      if (isa<TypeAliasDecl>(VD))
+        return true;
+    }
+  }
   if (D->isPrivateStdlibDecl(false))
     return true;
   if (AvailableAttr::isUnavailable(D))
     return true;
   if (isa<ConstructorDecl>(D))
     return false;
-  if (isa<OperatorDecl>(D))
-    return true;
   if (auto VD = dyn_cast<ValueDecl>(D)) {
     if (VD->getBaseName().empty())
       return true;
-
-    // Exclude type alias decls because they should have no impact on ABI.
-    if (isa<TypeAliasDecl>(VD) && Ctx.checkingABI())
-      return true;
     switch (VD->getFormalAccess()) {
     case AccessLevel::Internal:
     case AccessLevel::Private:
     case AccessLevel::FilePrivate:
-      // Private vars with fixed binary orders can have ABI-impact, so we should
-      // whitelist them if we're checking ABI.
-      if (Ctx.checkingABI() && getFixedBinaryOrder(VD).hasValue())
-        break;
       return true;
     case AccessLevel::Public:
     case AccessLevel::Open:
@@ -1340,6 +1371,8 @@
       KnownDecls.insert(D);
       if (auto VD = dyn_cast<ValueDecl>(D))
         foundDecl(VD, DeclVisibilityKind::DynamicLookup);
+      else
+        processDecl(D);
     }
   }
 
@@ -1353,7 +1386,7 @@
      });
 
   for (auto *VD : ClangMacros)
-    processDecl(VD);
+    processValueDecl(VD);
 
   // Collect extensions to types from other modules and synthesize type nodes
   // for them.
@@ -1370,7 +1403,18 @@
   }
 }
 
-void SwiftDeclCollector::processDecl(ValueDecl *VD) {
+SDKNode *SwiftDeclCollector::constructOperatorDeclNode(OperatorDecl *OD) {
+  return SDKNodeInitInfo(Ctx, OD).createSDKNode(SDKNodeKind::DeclOperator);
+}
+
+void SwiftDeclCollector::processDecl(Decl *D) {
+  assert(!isa<ValueDecl>(D));
+  if (auto *OD = dyn_cast<OperatorDecl>(D)) {
+    RootNode->addChild(constructOperatorDeclNode(OD));
+  }
+}
+
+void SwiftDeclCollector::processValueDecl(ValueDecl *VD) {
   if (auto FD = dyn_cast<FuncDecl>(VD)) {
     RootNode->addChild(constructFunctionNode(FD, SDKNodeKind::DeclFunction));
   } else if (auto NTD = dyn_cast<NominalTypeDecl>(VD)) {
@@ -1391,7 +1435,7 @@
     return;
   }
 
-  processDecl(VD);
+  processValueDecl(VD);
 }
 
 void SDKNode::output(json::Output &out, KeyKind Key, bool Value) {
diff --git a/tools/swift-api-digester/ModuleAnalyzerNodes.h b/tools/swift-api-digester/ModuleAnalyzerNodes.h
index 42dd277..bce2ca9 100644
--- a/tools/swift-api-digester/ModuleAnalyzerNodes.h
+++ b/tools/swift-api-digester/ModuleAnalyzerNodes.h
@@ -339,12 +339,7 @@
   SDKNodeRoot(SDKNodeInitInfo Info);
   static SDKNode *getInstance(SDKContext &Ctx);
   static bool classof(const SDKNode *N);
-  void registerDescendant(SDKNode *D) {
-    if (auto DD = dyn_cast<SDKNodeDecl>(D)) {
-      assert(!DD->getUsr().empty());
-      DescendantDeclTable[DD->getUsr()].insert(DD);
-    }
-  }
+  void registerDescendant(SDKNode *D);
   ArrayRef<SDKNodeDecl*> getDescendantsByUsr(StringRef Usr) {
     return DescendantDeclTable[Usr].getArrayRef();
   }
@@ -468,6 +463,12 @@
   void diagnose(SDKNode *Right) override;
 };
 
+class SDKNodeDeclOperator : public SDKNodeDecl {
+public:
+  SDKNodeDeclOperator(SDKNodeInitInfo Info);
+  static bool classof(const SDKNode *N);
+};
+
 class SDKNodeDeclTypeAlias : public SDKNodeDecl {
 public:
   SDKNodeDeclTypeAlias(SDKNodeInitInfo Info);
@@ -600,13 +601,15 @@
   SDKNode *constructTypeDeclNode(NominalTypeDecl *NTD);
   SDKNode *constructInitNode(ConstructorDecl *CD);
   SDKNode *constructFunctionNode(FuncDecl* FD, SDKNodeKind Kind);
+  SDKNode *constructOperatorDeclNode(OperatorDecl *OD);
   std::vector<SDKNode*> createParameterNodes(ParameterList *PL);
   SDKNode *constructTypeNode(Type T, bool IsImplicitlyUnwrappedOptional = false,
     bool hasDefaultArgument = false);
+  void processValueDecl(ValueDecl *VD);
+  void foundDecl(ValueDecl *VD, DeclVisibilityKind Reason) override;
+  void processDecl(Decl *D);
 public:
   void lookupVisibleDecls(ArrayRef<ModuleDecl *> Modules);
-  void processDecl(ValueDecl *VD);
-  void foundDecl(ValueDecl *VD, DeclVisibilityKind Reason) override;
 };
 
 int dumpSwiftModules(const CompilerInvocation &InitInvok,
diff --git a/tools/swift-api-digester/ModuleDiagsConsumer.cpp b/tools/swift-api-digester/ModuleDiagsConsumer.cpp
index e55bc63..087102a 100644
--- a/tools/swift-api-digester/ModuleDiagsConsumer.cpp
+++ b/tools/swift-api-digester/ModuleDiagsConsumer.cpp
@@ -54,6 +54,7 @@
     return "/* Generic Signature Changes */";
   case LocalDiagID::decl_added:
   case LocalDiagID::decl_reorder:
+  case LocalDiagID::decl_has_fixed_order_change:
     return "/* Fixed-layout Type Changes */";
   case LocalDiagID::conformance_added:
   case LocalDiagID::conformance_removed:
diff --git a/tools/swift-api-digester/swift-api-digester.cpp b/tools/swift-api-digester/swift-api-digester.cpp
index 8e949d1..6b36d0e 100644
--- a/tools/swift-api-digester/swift-api-digester.cpp
+++ b/tools/swift-api-digester/swift-api-digester.cpp
@@ -808,6 +808,10 @@
                             getScreenInfo());
   }
   if (Ctx.checkingABI()) {
+    if (hasFixedBinaryOrder() != RV->hasFixedBinaryOrder()) {
+      Ctx.getDiags().diagnose(SourceLoc(), diag::decl_has_fixed_order_change,
+                              getScreenInfo(), hasFixedBinaryOrder());
+    }
     if (hasFixedBinaryOrder() && RV->hasFixedBinaryOrder() &&
         getFixedBinaryOrder() != RV->getFixedBinaryOrder()) {
       Ctx.getDiags().diagnose(SourceLoc(), diag::decl_reorder,
@@ -938,14 +942,7 @@
       }
       // Complain about added protocol requirements
       if (auto *D = dyn_cast<SDKNodeDecl>(Right)) {
-        if (D->isProtocolRequirement()) {
-          bool ShouldComplain = !D->isOverriding();
-          // We should allow added associated types with default.
-          if (auto ATD = dyn_cast<SDKNodeDeclAssociatedType>(D)) {
-            if (ATD->getDefault())
-              ShouldComplain = false;
-          }
-          if (ShouldComplain)
+        if (D->isProtocolRequirement() && !D->isOverriding()) {
             Ctx.getDiags().diagnose(SourceLoc(), diag::protocol_req_added,
                                     D->getScreenInfo());
         }
@@ -1000,6 +997,7 @@
       break;
     }
 
+    case SDKNodeKind::DeclOperator:
     case SDKNodeKind::DeclSubscript:
     case SDKNodeKind::DeclAssociatedType:
     case SDKNodeKind::DeclFunction:
diff --git a/unittests/SourceKit/SwiftLang/EditingTest.cpp b/unittests/SourceKit/SwiftLang/EditingTest.cpp
index c2c4747..7fafc25 100644
--- a/unittests/SourceKit/SwiftLang/EditingTest.cpp
+++ b/unittests/SourceKit/SwiftLang/EditingTest.cpp
@@ -137,7 +137,7 @@
   }
 
   bool waitForDocUpdate(bool reset = false) {
-    std::chrono::seconds secondsToWait(10);
+    std::chrono::seconds secondsToWait(20);
     std::unique_lock<std::mutex> lk(DocUpdState->Mtx);
     auto when = std::chrono::system_clock::now() + secondsToWait;
     auto result = !DocUpdState->CV.wait_until(
diff --git a/utils/build-presets.ini b/utils/build-presets.ini
index 49f582a..abb58ff 100644
--- a/utils/build-presets.ini
+++ b/utils/build-presets.ini
@@ -1024,7 +1024,6 @@
 reconfigure
 
 swift-install-components=compiler;clang-builtin-headers;stdlib;swift-syntax;sdk-overlay;license;sourcekit-xpc-service;swift-remote-mirror;swift-remote-mirror-headers
-llvm-install-components=libclang;libclang-headers
 
 # Path to the .tar.gz package we would create.
 installable-package=%(installable_package)s
diff --git a/utils/vim/syntax/swift.vim b/utils/vim/syntax/swift.vim
index 4829e58..3ba9a5c 100644
--- a/utils/vim/syntax/swift.vim
+++ b/utils/vim/syntax/swift.vim
@@ -32,7 +32,7 @@
 syn match swiftMultiwordKeyword
       \ "indirect case"
 
-syn keyword swiftImport skipwhite nextgroup=swiftImportModule
+syn keyword swiftImport skipwhite skipempty nextgroup=swiftImportModule
       \ import
 
 syn keyword swiftDefinitionModifier
@@ -52,7 +52,7 @@
       \ throws
       \ weak
 
-syn keyword swiftInOutKeyword skipwhite nextgroup=swiftTypeName
+syn keyword swiftInOutKeyword skipwhite skipempty nextgroup=swiftTypeName
       \ inout
 
 syn keyword swiftIdentifierKeyword
@@ -61,7 +61,7 @@
       \ self
       \ super
 
-syn keyword swiftFuncKeywordGeneral skipwhite nextgroup=swiftTypeParameters
+syn keyword swiftFuncKeywordGeneral skipwhite skipempty nextgroup=swiftTypeParameters
       \ init
 
 syn keyword swiftFuncKeyword
@@ -71,12 +71,12 @@
 syn keyword swiftScope
       \ autoreleasepool
 
-syn keyword swiftMutating skipwhite nextgroup=swiftFuncDefinition
+syn keyword swiftMutating skipwhite skipempty nextgroup=swiftFuncDefinition
       \ mutating
-syn keyword swiftFuncDefinition skipwhite nextgroup=swiftTypeName,swiftOperator
+syn keyword swiftFuncDefinition skipwhite skipempty nextgroup=swiftTypeName,swiftOperator
       \ func
 
-syn keyword swiftTypeDefinition skipwhite nextgroup=swiftTypeName
+syn keyword swiftTypeDefinition skipwhite skipempty nextgroup=swiftTypeName
       \ class
       \ enum
       \ extension
@@ -84,10 +84,10 @@
       \ struct
       \ typealias
 
-syn match swiftMultiwordTypeDefinition skipwhite nextgroup=swiftTypeName
+syn match swiftMultiwordTypeDefinition skipwhite skipempty nextgroup=swiftTypeName
       \ "indirect enum"
 
-syn keyword swiftVarDefinition skipwhite nextgroup=swiftVarName
+syn keyword swiftVarDefinition skipwhite skipempty nextgroup=swiftVarName
       \ let
       \ var
 
@@ -109,20 +109,20 @@
 syn match swiftImportComponent contained nextgroup=swiftImportComponent
       \ /\.\<[A-Za-z_][A-Za-z_0-9]*\>/
 
-syn match swiftTypeName contained skipwhite nextgroup=swiftTypeParameters
+syn match swiftTypeName contained skipwhite skipempty nextgroup=swiftTypeParameters
       \ /\<[A-Za-z_][A-Za-z_0-9\.]*\>/
-syn match swiftVarName contained skipwhite nextgroup=swiftTypeDeclaration
+syn match swiftVarName contained skipwhite skipempty nextgroup=swiftTypeDeclaration
       \ /\<[A-Za-z_][A-Za-z_0-9]*\>/
 syn match swiftImplicitVarName
       \ /\$\<[A-Za-z_0-9]\+\>/
 
 " TypeName[Optionality]?
-syn match swiftType contained skipwhite nextgroup=swiftTypeParameters
+syn match swiftType contained skipwhite skipempty nextgroup=swiftTypeParameters
       \ /\<[A-Za-z_][A-Za-z_0-9\.]*\>[!?]\?/
 " [Type:Type] (dictionary) or [Type] (array)
 syn region swiftType contained contains=swiftTypePair,swiftType
       \ matchgroup=Delimiter start=/\[/ end=/\]/
-syn match swiftTypePair contained skipwhite nextgroup=swiftTypeParameters,swiftTypeDeclaration
+syn match swiftTypePair contained skipwhite skipempty nextgroup=swiftTypeParameters,swiftTypeDeclaration
       \ /\<[A-Za-z_][A-Za-z_0-9\.]*\>[!?]\?/
 " (Type[, Type]) (tuple)
 " FIXME: we should be able to use skip="," and drop swiftParamDelim
@@ -136,9 +136,9 @@
 syn keyword swiftConstraint contained
       \ where
 
-syn match swiftTypeDeclaration skipwhite nextgroup=swiftType,swiftInOutKeyword
+syn match swiftTypeDeclaration skipwhite skipempty nextgroup=swiftType,swiftInOutKeyword
       \ /:/
-syn match swiftTypeDeclaration skipwhite nextgroup=swiftType
+syn match swiftTypeDeclaration skipwhite skipempty nextgroup=swiftType
       \ /->/
 
 syn region swiftParenthesisRegion matchgroup=NONE start=/(/ end=/)/ contains=TOP
@@ -153,8 +153,8 @@
 syn match swiftOct /[+\-]\?\<0o[0-7][0-7_]*\>/
 syn match swiftBin /[+\-]\?\<0b[01][01_]*\>/
 
-syn match swiftOperator +\.\@<!\.\.\.\@!\|[/=\-+*%<>!&|^~]\@<!\(/[/*]\@![/=\-+*%<>!&|^~]*\|*/\@![/=\-+*%<>!&|^~]*\|->\@![/=\-+*%<>!&|^~]*\|[=+%<>!&|^~][/=\-+*%<>!&|^~]*\)+ skipwhite nextgroup=swiftTypeParameters
-syn match swiftOperator "\.\.[<.]" skipwhite nextgroup=swiftTypeParameters
+syn match swiftOperator +\.\@<!\.\.\.\@!\|[/=\-+*%<>!&|^~]\@<!\(/[/*]\@![/=\-+*%<>!&|^~]*\|*/\@![/=\-+*%<>!&|^~]*\|->\@![/=\-+*%<>!&|^~]*\|[=+%<>!&|^~][/=\-+*%<>!&|^~]*\)+ skipwhite skipempty nextgroup=swiftTypeParameters
+syn match swiftOperator "\.\.[<.]" skipwhite skipempty nextgroup=swiftTypeParameters
 
 syn match swiftChar /'\([^'\\]\|\\\(["'tnr0\\]\|x[0-9a-fA-F]\{2}\|u[0-9a-fA-F]\{4}\|U[0-9a-fA-F]\{8}\)\)'/
 
@@ -167,12 +167,12 @@
 syn match swiftPreproc /^\s*#\(\<if\>\|\<else\>\|\<elseif\>\|\<endif\>\|\<error\>\|\<warning\>\)/
 syn region swiftPreprocFalse start="^\s*#\<if\>\s\+\<false\>" end="^\s*#\(\<else\>\|\<elseif\>\|\<endif\>\)"
 
-syn match swiftAttribute /@\<\w\+\>/ skipwhite nextgroup=swiftType
+syn match swiftAttribute /@\<\w\+\>/ skipwhite skipempty nextgroup=swiftType
 
 syn keyword swiftTodo MARK TODO FIXME contained
 
-syn match swiftCastOp "\<is\>" skipwhite nextgroup=swiftType
-syn match swiftCastOp "\<as\>[!?]\?" skipwhite nextgroup=swiftType
+syn match swiftCastOp "\<is\>" skipwhite skipempty nextgroup=swiftType
+syn match swiftCastOp "\<as\>[!?]\?" skipwhite skipempty nextgroup=swiftType
 
 syn match swiftNilOps "??"
 
diff --git a/validation-test/ModuleInterface/verify_all_overlays.swift b/validation-test/ModuleInterface/verify_all_overlays.swift
index 42b8a4a..6e35422 100644
--- a/validation-test/ModuleInterface/verify_all_overlays.swift
+++ b/validation-test/ModuleInterface/verify_all_overlays.swift
@@ -1,5 +1,5 @@
 // RUN: %empty-directory(%t)
-// RUN: for x in %platform-sdk-overlay-dir/*.swiftinterface; do [[ $(basename "$x") = Swift.swiftinterface || $(basename "$x") = simd.swiftinterface ]] && continue; %target-swift-frontend "$x" -emit-module -o %t/$(basename "${x/.*}").swiftmodule -disable-objc-attr-requires-foundation-module -enable-resilience -Fsystem %sdk/System/Library/PrivateFrameworks/ -swift-version 4 || echo '%target-os:' $(basename "$x") >> %t/failures.txt; done
+// RUN: for x in %platform-sdk-overlay-dir/*.swiftinterface; do [[ $(basename "$x") = Swift.swiftinterface || $(basename "$x") = simd.swiftinterface || $(basename "$x") = SwiftLang.swiftinterface ]] && continue; %target-swift-frontend "$x" -emit-module -o %t/$(basename "${x/.*}").swiftmodule -disable-objc-attr-requires-foundation-module -enable-resilience -Fsystem %sdk/System/Library/PrivateFrameworks/ -swift-version 4 || echo '%target-os:' $(basename "$x") >> %t/failures.txt; done
 // RUN: diff <(grep '%target-os:' %s) <(sort -f %t/failures.txt)
 
 // REQUIRES: nonexecutable_test
@@ -13,9 +13,6 @@
 tvos: CloudKit.swiftinterface
 watchos: CloudKit.swiftinterface
 
-// Missing search path for sourcekitd.framework.
-macosx: SwiftLang.swiftinterface
-
 // Needs to be built as Swift 4.2.
 ios: UIKit.swiftinterface
 tvos: UIKit.swiftinterface
diff --git a/validation-test/ModuleInterface/verify_all_overlays_O.swift b/validation-test/ModuleInterface/verify_all_overlays_O.swift
index d09a198..1412af2 100644
--- a/validation-test/ModuleInterface/verify_all_overlays_O.swift
+++ b/validation-test/ModuleInterface/verify_all_overlays_O.swift
@@ -1,5 +1,5 @@
 // RUN: %empty-directory(%t)
-// RUN: for x in %platform-sdk-overlay-dir/*.swiftinterface; do [[ $(basename "$x") = Swift.swiftinterface || $(basename "$x") = simd.swiftinterface ]] && continue; %target-swift-frontend "$x" -emit-module -o %t/$(basename "${x/.*}").swiftmodule -disable-objc-attr-requires-foundation-module -enable-resilience -Fsystem %sdk/System/Library/PrivateFrameworks/ -swift-version 4 -O || echo '%target-os:' $(basename "$x") >> %t/failures.txt; done
+// RUN: for x in %platform-sdk-overlay-dir/*.swiftinterface; do [[ $(basename "$x") = Swift.swiftinterface || $(basename "$x") = simd.swiftinterface || $(basename "$x") = SwiftLang.swiftinterface ]] && continue; %target-swift-frontend "$x" -emit-module -o %t/$(basename "${x/.*}").swiftmodule -disable-objc-attr-requires-foundation-module -enable-resilience -Fsystem %sdk/System/Library/PrivateFrameworks/ -swift-version 4 -O || echo '%target-os:' $(basename "$x") >> %t/failures.txt; done
 // RUN: diff <(grep '%target-os:' %s) <(sort -f %t/failures.txt)
 
 // REQUIRES: nonexecutable_test
@@ -13,9 +13,6 @@
 tvos: CloudKit.swiftinterface
 watchos: CloudKit.swiftinterface
 
-// Missing search path for sourcekitd.framework.
-macosx: SwiftLang.swiftinterface
-
 // Needs to be built as Swift 4.2.
 ios: UIKit.swiftinterface
 tvos: UIKit.swiftinterface